A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 

A

ABlockReader - Interface in org.apache.accumulo.core.file.blockfile
 
ABlockWriter - Interface in org.apache.accumulo.core.file.blockfile
 
AboutCommand - Class in org.apache.accumulo.core.util.shell.commands
 
AboutCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.AboutCommand
 
AbstractInputFormat<K,V> - Class in org.apache.accumulo.core.client.mapred
An abstract input format to provide shared methods common to all other input format classes.
AbstractInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AbstractInputFormat
 
AbstractInputFormat<K,V> - Class in org.apache.accumulo.core.client.mapreduce
An abstract input format to provide shared methods common to all other input format classes.
AbstractInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
 
AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapred
An abstract base class to be used to create RecordReader instances that convert from Accumulo Key/Value pairs to the user's K/V types.
AbstractInputFormat.AbstractRecordReader() - Constructor for class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
 
AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapreduce
An abstract base class to be used to create RecordReader instances that convert from Accumulo Key/Value pairs to the user's K/V types.
AbstractInputFormat.AbstractRecordReader() - Constructor for class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
 
accept(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration.AllFilter
 
accept(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration.PrefixFilter
 
accept(String) - Method in interface org.apache.accumulo.core.conf.AccumuloConfiguration.PropertyFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.Filter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
Accepts entries whose timestamps are less than currentTime - threshold.
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.ReqVisFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
acceptRow(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
Implementation should return false to suppress a row.
access(long) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
Block has been accessed.
ACCUMULO_NAMESPACE - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
 
ACCUMULO_NAMESPACE_ID - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
 
AccumuloConfiguration - Class in org.apache.accumulo.core.conf
 
AccumuloConfiguration() - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration
 
AccumuloConfiguration.AllFilter - Class in org.apache.accumulo.core.conf
 
AccumuloConfiguration.AllFilter() - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration.AllFilter
 
AccumuloConfiguration.PrefixFilter - Class in org.apache.accumulo.core.conf
 
AccumuloConfiguration.PrefixFilter(String) - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration.PrefixFilter
 
AccumuloConfiguration.PropertyFilter - Interface in org.apache.accumulo.core.conf
 
AccumuloException - Exception in org.apache.accumulo.core.client
A generic Accumulo Exception for general accumulo failures.
AccumuloException(String) - Constructor for exception org.apache.accumulo.core.client.AccumuloException
 
AccumuloException(Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloException
 
AccumuloException(String, Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloException
 
AccumuloFileOutputFormat - Class in org.apache.accumulo.core.client.mapred
This class allows MapReduce jobs to write output in the Accumulo data file format.
Care should be taken to write only sorted data (sorted by Key), as this is an important requirement of Accumulo data files.
AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
 
AccumuloFileOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
This class allows MapReduce jobs to write output in the Accumulo data file format.
Care should be taken to write only sorted data (sorted by Key), as this is an important requirement of Accumulo data files.
AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
AccumuloInputFormat - Class in org.apache.accumulo.core.client.mapred
This class allows MapReduce jobs to use Accumulo as the source of data.
AccumuloInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloInputFormat
 
AccumuloInputFormat - Class in org.apache.accumulo.core.client.mapreduce
This class allows MapReduce jobs to use Accumulo as the source of data.
AccumuloInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
AccumuloMultiTableInputFormat - Class in org.apache.accumulo.core.client.mapred
This class allows MapReduce jobs to use multiple Accumulo tables as the source of data.
AccumuloMultiTableInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloMultiTableInputFormat
 
AccumuloMultiTableInputFormat - Class in org.apache.accumulo.core.client.mapreduce
This class allows MapReduce jobs to use multiple Accumulo tables as the source of data.
AccumuloMultiTableInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
 
AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapred
This class allows MapReduce jobs to use Accumulo as the sink for data.
AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
 
AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
This class allows MapReduce jobs to use Accumulo as the sink for data.
AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
AccumuloOutputFormat.AccumuloRecordWriter - Class in org.apache.accumulo.core.client.mapred
A base class to be used to create RecordWriter instances that write to Accumulo.
AccumuloOutputFormat.AccumuloRecordWriter(JobConf) - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
 
AccumuloOutputFormat.AccumuloRecordWriter - Class in org.apache.accumulo.core.client.mapreduce
A base class to be used to create RecordWriter instances that write to Accumulo.
AccumuloOutputFormat.AccumuloRecordWriter(TaskAttemptContext) - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
 
AccumuloRowInputFormat - Class in org.apache.accumulo.core.client.mapred
This class allows MapReduce jobs to use Accumulo as the source of data.
AccumuloRowInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloRowInputFormat
 
AccumuloRowInputFormat - Class in org.apache.accumulo.core.client.mapreduce
This class allows MapReduce jobs to use Accumulo as the source of data.
AccumuloRowInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloRowInputFormat
 
AccumuloSecurityException - Exception in org.apache.accumulo.core.client
An Accumulo Exception for security violations, authentication failures, authorization failures, etc.
AccumuloSecurityException(ThriftSecurityException) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
Construct a user-facing exception from a serialized version.
AccumuloSecurityException(String, SecurityErrorCode, Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloSecurityException(String, SecurityErrorCode, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloSecurityException(String, SecurityErrorCode) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloSecurityException(String, SecurityErrorCode, String) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloServerException - Exception in org.apache.accumulo.core.client.impl
This class is intended to encapsulate errors that occurred on the server side.
AccumuloServerException(String, TApplicationException) - Constructor for exception org.apache.accumulo.core.client.impl.AccumuloServerException
 
ActionStats - Class in org.apache.accumulo.core.tabletserver.thrift
 
ActionStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
ActionStats(int, double, int, long, double, int, double, double) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
ActionStats(ActionStats) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Performs a deep copy on other.
ActionStats._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActiveCompaction - Class in org.apache.accumulo.core.client.admin
 
ActiveCompaction() - Constructor for class org.apache.accumulo.core.client.admin.ActiveCompaction
 
ActiveCompaction - Class in org.apache.accumulo.core.tabletserver.thrift
 
ActiveCompaction() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
ActiveCompaction(TKeyExtent, long, List<String>, String, CompactionType, CompactionReason, String, long, long, List<IterInfo>, Map<String, Map<String, String>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
ActiveCompaction(ActiveCompaction) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Performs a deep copy on other.
ActiveCompaction._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActiveCompaction.CompactionReason - Enum in org.apache.accumulo.core.client.admin
 
ActiveCompaction.CompactionType - Enum in org.apache.accumulo.core.client.admin
 
ActiveCompactionImpl - Class in org.apache.accumulo.core.client.impl
 
ActiveScan - Class in org.apache.accumulo.core.client.admin
A class that contains information about an ActiveScan
ActiveScan() - Constructor for class org.apache.accumulo.core.client.admin.ActiveScan
 
ActiveScan - Class in org.apache.accumulo.core.tabletserver.thrift
 
ActiveScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
ActiveScan(String, String, String, long, long, ScanType, ScanState, TKeyExtent, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
ActiveScan(ActiveScan) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Performs a deep copy on other.
ActiveScan._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActiveScanImpl - Class in org.apache.accumulo.core.client.impl
A class that contains information about an ActiveScan
add(Key) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
add(Key) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
add(Key) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Adds a key to this filter.
add(List<Key>) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Adds a list of keys to this filter.
add(Collection<Key>) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Adds a collection of keys to this filter.
add(Key[]) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Adds an array of keys to this filter.
add(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
 
add(ConstraintViolationSummary) - Method in class org.apache.accumulo.core.constraints.Violations
 
add(Violations) - Method in class org.apache.accumulo.core.constraints.Violations
 
add(List<ConstraintViolationSummary>) - Method in class org.apache.accumulo.core.constraints.Violations
 
add(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
Attempt to add the specified cached block to this queue.
add(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
 
add(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
add(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Writer
 
add(Text) - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
 
add(Text, Text) - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
 
add(ColumnVisibility.Node) - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
add(byte[], int, int) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 
add(boolean) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 
AddAuthsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
AddAuthsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.AddAuthsCommand
 
addCacheFile(URI, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
 
addCondition(Condition) - Method in class org.apache.accumulo.core.data.ConditionalMutation
 
addConstraint(String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Add a new constraint to a namespace.
addConstraint(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Add a new constraint to a table.
addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
addIterator(JobConf, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Encode an iterator on the input for this job.
addIterator(Job, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Encode an iterator on the single input table for this job.
addIterator(Class<?>, Configuration, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Encode an iterator on the input for the single input table associated with this job.
addIterator(Class<?>, Configuration, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
addLast(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
 
addLast(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Writer
 
addListDeleteGroup(String) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
addMutation(Mutation) - Method in interface org.apache.accumulo.core.client.BatchWriter
Queues one mutation to write.
addMutation(Mutation) - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
 
addMutation(KeyExtent, T) - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletServerMutations
 
addMutation(String, Mutation) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
 
addMutation(String, Iterator<Mutation>) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
 
addMutation(String, Mutation) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
addMutation(Mutation) - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
 
addMutations(Iterable<Mutation>) - Method in interface org.apache.accumulo.core.client.BatchWriter
Queues several mutations to write.
addMutations(Iterable<Mutation>) - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
 
addMutations(Iterable<Mutation>) - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
 
addNamedOption(String, String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
addNode(RemoteSpan) - Method in class org.apache.accumulo.core.trace.SpanTree
 
addObject(Text, K) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
addObject(Text, Text, K) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
addObserver(ConfigurationObserver) - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
Adds an observer.
addOption(String, String) - Method in class org.apache.accumulo.core.client.IteratorSetting
Add another option to the iterator.
addOptions(Set<Map.Entry<String, String>>) - Method in class org.apache.accumulo.core.client.IteratorSetting
Add many options to the iterator.
addOptions(Map<String, String>) - Method in class org.apache.accumulo.core.client.IteratorSetting
Add many options to the iterator.
addRange(Map<String, Map<KeyExtent, List<Range>>>, String, KeyExtent, Range) - Static method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
AddressUtil - Class in org.apache.accumulo.core.util
 
AddressUtil() - Constructor for class org.apache.accumulo.core.util.AddressUtil
 
addScanIterator(IteratorSetting) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Adds server-side scan iterators.
addScanIterator(IteratorSetting) - Method in interface org.apache.accumulo.core.client.ScannerBase
Add a server-side scan iterator.
addScanIterators(Shell, CommandLine, Scanner, String) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
addSource(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
 
addSource(SortedKeyValueIterator<Key, Value>, IteratorEnvironment, Text, boolean) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
Deprecated.
since 1.6.0
addSplits(String, SortedSet<Text>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Ensures that tablets are split along a set of keys.
addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
addSplits(SortedSet<Text>) - Method in class org.apache.accumulo.core.client.mock.MockTable
 
AddSplitsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
AddSplitsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.AddSplitsCommand
 
addStat(long) - Method in class org.apache.accumulo.core.util.Stat
 
addSubcommand(Token) - Method in class org.apache.accumulo.core.util.shell.Token
 
addSubcommand(Collection<String>) - Method in class org.apache.accumulo.core.util.shell.Token
 
addTable(Text) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
 
addTable(Text) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
 
addTerm(SortedKeyValueIterator<Key, Value>, Text, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
addToArguments(ByteBuffer) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
addToConditions(TCondition) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
addToDeadTabletServers(DeadServer) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
addToFilenames(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
addToFiles(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
addToFullScans(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
addToInputFiles(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
addToIterators(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
addToLogSorts(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
addToMutations(TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
addToNewTablets(TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
addToResults(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
addToResults(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
addToServersShuttingDown(String) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
addToSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
addToSuccess(TDiskUsage) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
addToSuccess(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
addToSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
addToSuccess(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
addToSuccess(TCMResult) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
addToSuccess(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
addToSuccess(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
addToSuccess(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
addToSymbols(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
addToTables(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
addToTables(String) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
addToTServerInfo(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
addToValues(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
addToViolationSummaries(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
addToViolationSummaries(TConstraintViolationSummary) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
addTTL(IteratorSetting, IteratorSetting.Column, Long) - Static method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
A convenience method for adding or changing an age off threshold for a column.
addUnnamedOption(String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
afterEndKey(Key) - Method in class org.apache.accumulo.core.data.Range
 
age - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
age - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
AgeOffFilter - Class in org.apache.accumulo.core.iterators.user
A filter that ages off key/value pairs based on the Key's timestamp.
AgeOffFilter() - Constructor for class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
aggregate() - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
Deprecated.
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
Deprecated.
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
Deprecated.
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
Deprecated.
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
Deprecated.
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
Deprecated.
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
Deprecated.
 
aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
Generate statistics from each Map.Entry, called for each entry to be iterated over.
aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
 
aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
 
AggregatingFormatter - Class in org.apache.accumulo.core.util.format
Formatter that will aggregate entries for various display purposes.
AggregatingFormatter() - Constructor for class org.apache.accumulo.core.util.format.AggregatingFormatter
 
AggregatingIterator - Class in org.apache.accumulo.core.iterators
Deprecated.
since 1.4, replaced by Combiner
AggregatingIterator() - Constructor for class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
AggregatingIterator(SortedKeyValueIterator<Key, Value>, ColumnToClassMapping<Aggregator>) - Constructor for class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
Aggregator - Interface in org.apache.accumulo.core.iterators.aggregation
Deprecated.
since 1.4, replaced by Combiner
AggregatorConfiguration - Class in org.apache.accumulo.core.iterators.aggregation.conf
Deprecated.
since 1.4
AggregatorConfiguration(Text, String) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorConfiguration
Deprecated.
 
AggregatorConfiguration(Text, Text, String) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorConfiguration
Deprecated.
 
AggregatorSet - Class in org.apache.accumulo.core.iterators.aggregation.conf
Deprecated.
since 1.4
AggregatorSet(Map<String, String>) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
Deprecated.
 
AggregatorSet() - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
Deprecated.
 
align(int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Aligns a number to 8.
align(long) - Static method in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Aligns a number to 8.
ALL_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
 
and(Filter) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
and(Filter) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
and(Filter) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Peforms a logical AND between this filter and a specified filter.
and(ArgumentChecker.Validator<T>) - Method in class org.apache.accumulo.core.util.ArgumentChecker.Validator
 
append(Key, Value) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
append(Key, Value) - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
append(Key, Value) - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
append(Key, Value) - Method in interface org.apache.accumulo.core.iterators.user.TransformingIterator.KVBuffer
 
append(LoggingEvent) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
appendPrintableString(byte[], int, int, int, StringBuilder) - Static method in class org.apache.accumulo.core.data.Key
 
appendText(StringBuilder, Text) - Static method in class org.apache.accumulo.core.util.format.BinaryFormatter
 
applyUpdates(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
applyUpdates(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
applyUpdates(TInfo, long, TKeyExtent, List<TMutation>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
applyUpdates(TInfo, long, TKeyExtent, List<TMutation>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
args - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
ArgumentChecker - Class in org.apache.accumulo.core.util
This class provides methods to check arguments of a variable number for null values, or anything else that might be required on a routine basis.
ArgumentChecker() - Constructor for class org.apache.accumulo.core.util.ArgumentChecker
 
ArgumentChecker.Validator<T> - Class in org.apache.accumulo.core.util
 
ArgumentChecker.Validator() - Constructor for class org.apache.accumulo.core.util.ArgumentChecker.Validator
 
arguments - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
ARRAY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Array overhead
arrayAdd(List<Long>, List<Long>) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
ArrayByteSequence - Class in org.apache.accumulo.core.data
 
ArrayByteSequence(byte[]) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
 
ArrayByteSequence(byte[], int, int) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
 
ArrayByteSequence(String) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
 
ArrayByteSequence(ByteBuffer) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
 
ARRAYLIST - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for ArrayList(0)
asList() - Method in class org.apache.accumulo.core.constraints.Violations
 
asThriftException() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AsyncSocketAppender - Class in org.apache.accumulo.core.util
An asynchronous appender that maintains its own internal socket appender.
AsyncSocketAppender() - Constructor for class org.apache.accumulo.core.util.AsyncSocketAppender
Creates a new appender.
ATOMIC_BOOLEAN - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for AtomicBoolean
ATOMIC_INTEGER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for AtomicInteger
ATOMIC_LONG - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for AtomicLong
attachIterator(String, IteratorSetting) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Add an iterator to a namespace on all scopes.
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Add an iterator to a namespace on the given scopes.
attachIterator(String, IteratorSetting) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Add an iterator to a table on all scopes.
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Add an iterator to a table on the given scopes.
attachIterator(String, IteratorSetting) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
attachIterator(String, IteratorSetting) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
AUTH_OPT - Static variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
authenticate(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
authenticate(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
authenticate(TInfo, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
authenticate(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
AuthenticateCommand - Class in org.apache.accumulo.core.util.shell.commands
 
AuthenticateCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.AuthenticateCommand
 
authenticateUser(String, byte[]) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
authenticateUser(String, AuthenticationToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Verify a username/password combination is valid
authenticateUser(String, byte[]) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
Deprecated.
authenticateUser(String, AuthenticationToken) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
authenticateUser(TInfo, TCredentials, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
authenticateUser(TInfo, TCredentials, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
authenticateUser(TInfo, TCredentials, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
authenticateUser(TInfo, TCredentials, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
AuthenticationToken - Interface in org.apache.accumulo.core.client.security.tokens
 
AuthenticationToken.AuthenticationTokenSerializer - Class in org.apache.accumulo.core.client.security.tokens
A utility class to serialize/deserialize AuthenticationToken objects.
Unfortunately, these methods are provided in an inner-class, to avoid breaking the interface API.
AuthenticationToken.AuthenticationTokenSerializer() - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
 
AuthenticationToken.Properties - Class in org.apache.accumulo.core.client.security.tokens
 
AuthenticationToken.Properties() - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
AuthenticationToken.TokenProperty - Class in org.apache.accumulo.core.client.security.tokens
 
AuthenticationToken.TokenProperty(String, String, boolean) - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
AuthorizationContainer - Interface in org.apache.accumulo.core.security
An interface for classes that contain a collection of authorizations.
authorizationFailures - Variable in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
authorizations - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
authorizations - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
Authorizations - Class in org.apache.accumulo.core.security
A collection of authorization strings.
Authorizations(Collection<byte[]>) - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an authorization object from a collection of string authorizations that have each already been encoded as UTF-8 bytes.
Authorizations(List<ByteBuffer>) - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an authorization object from a list of string authorizations that have each already been encoded as UTF-8 bytes.
Authorizations(byte[]) - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an authorizations object from a serialized form.
Authorizations() - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an empty set of authorizations.
Authorizations(String...) - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an authorizations object from a set of human-readable authorizations.
authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
auths - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
auths - Variable in class org.apache.accumulo.core.client.mock.MockScannerBase
 
autoClean - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
available() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
available() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
 

B

BadArgumentException - Exception in org.apache.accumulo.core.util
 
BadArgumentException(String, String, int) - Constructor for exception org.apache.accumulo.core.util.BadArgumentException
 
badTServers - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
Base64 - Class in org.apache.accumulo.core.util
A wrapper around commons-codec's Base64 to make sure we get the non-chunked behavior that became the default in commons-codec version 1.5+ while relying on the commons-codec version 1.4 that Hadoop Client provides.
basePath - Variable in class org.apache.accumulo.core.volume.VolumeImpl
 
batch - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
BatchDeleter - Interface in org.apache.accumulo.core.client
Implementations of BatchDeleter support efficient deletion of ranges in accumulo.
batchLatency - Variable in class org.apache.accumulo.core.cli.BatchWriterOpts
 
batchMemory - Variable in class org.apache.accumulo.core.cli.BatchWriterOpts
 
BatchScanner - Interface in org.apache.accumulo.core.client
In exchange for possibly returning scanned entries out of order, BatchScanner implementations may scan an Accumulo table more efficiently by Looking up multiple ranges in parallel.
BatchScannerOpts - Class in org.apache.accumulo.core.cli
 
BatchScannerOpts() - Constructor for class org.apache.accumulo.core.cli.BatchScannerOpts
 
batchSize - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
batchThreads - Variable in class org.apache.accumulo.core.cli.BatchWriterOpts
 
batchTimeout - Variable in class org.apache.accumulo.core.cli.BatchWriterOpts
 
BatchWriter - Interface in org.apache.accumulo.core.client
Send Mutations to a single Table in Accumulo.
BatchWriterConfig - Class in org.apache.accumulo.core.client
This object holds configuration settings used to instantiate a BatchWriter
BatchWriterConfig() - Constructor for class org.apache.accumulo.core.client.BatchWriterConfig
 
BatchWriterImpl - Class in org.apache.accumulo.core.client.impl
 
BatchWriterImpl(Instance, Credentials, String, BatchWriterConfig) - Constructor for class org.apache.accumulo.core.client.impl.BatchWriterImpl
 
BatchWriterOpts - Class in org.apache.accumulo.core.cli
 
BatchWriterOpts() - Constructor for class org.apache.accumulo.core.cli.BatchWriterOpts
 
BCFile - Class in org.apache.accumulo.core.file.rfile.bcfile
Block Compressed file, the underlying physical storage layer for TFile.
BCFile.Reader - Class in org.apache.accumulo.core.file.rfile.bcfile
BCFile Reader, interface to read the file's data and meta blocks.
BCFile.Reader(FSDataInputStream, long, Configuration, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Constructor
BCFile.Reader(CachableBlockFile.Reader, FSDataInputStream, long, Configuration, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
BCFile.Reader.BlockReader - Class in org.apache.accumulo.core.file.rfile.bcfile
Access point to read a block.
BCFile.Writer - Class in org.apache.accumulo.core.file.rfile.bcfile
BCFile writer, the entry point for creating a new BCFile.
BCFile.Writer(FSDataOutputStream, String, Configuration, boolean, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Constructor
BCFile.Writer.BlockAppender - Class in org.apache.accumulo.core.file.rfile.bcfile
Access point to stuff data into a block.
beforeStartKey(Key) - Method in class org.apache.accumulo.core.data.Range
 
beginFateOperation(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient
 
beginFateOperation(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.FateService.AsyncIface
 
beginFateOperation(TInfo, TCredentials) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
beginFateOperation(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.master.thrift.FateService.Iface
 
BigDecimalCombiner - Class in org.apache.accumulo.core.iterators.user
A family of combiners that treat values as BigDecimals, encoding and decoding using the built-in BigDecimal String input/output functions.
BigDecimalCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
 
BigDecimalCombiner.BigDecimalEncoder - Class in org.apache.accumulo.core.iterators.user
Provides the ability to encode scientific notation.
BigDecimalCombiner.BigDecimalEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
 
BigDecimalCombiner.BigDecimalMaxCombiner - Class in org.apache.accumulo.core.iterators.user
 
BigDecimalCombiner.BigDecimalMaxCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalMaxCombiner
 
BigDecimalCombiner.BigDecimalMinCombiner - Class in org.apache.accumulo.core.iterators.user
 
BigDecimalCombiner.BigDecimalMinCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalMinCombiner
 
BigDecimalCombiner.BigDecimalSummingCombiner - Class in org.apache.accumulo.core.iterators.user
 
BigDecimalCombiner.BigDecimalSummingCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalSummingCombiner
 
BigIntegerLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder to encode/decode a BigInteger to/from bytes that maintain its native Java sort order.
BigIntegerLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
 
bigNumberForQuantity(long) - Static method in class org.apache.accumulo.core.util.NumUtil
 
bigNumberForQuantity(double) - Static method in class org.apache.accumulo.core.util.NumUtil
 
bigNumberForSize(long) - Static method in class org.apache.accumulo.core.util.NumUtil
 
BinaryFormatter - Class in org.apache.accumulo.core.util.format
 
BinaryFormatter() - Constructor for class org.apache.accumulo.core.util.format.BinaryFormatter
 
BinaryTree<T> - Class in org.apache.accumulo.core.util
A class for storing data as a binary tree.
BinaryTree() - Constructor for class org.apache.accumulo.core.util.BinaryTree
 
binMutations(Credentials, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
binMutations(Credentials, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
 
binMutations(Credentials, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
binMutations(Credentials, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
 
binMutations(Credentials, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
 
binMutations(List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>, TCredentials) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
Deprecated.
 
binOffline(String, List<Range>, Instance, Connector) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
 
binRanges(Credentials, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
binRanges(Credentials, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
 
binRanges(Credentials, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
binRanges(Credentials, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
 
binRanges(Credentials, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
 
binRanges(List<Range>, Map<String, Map<KeyExtent, List<Range>>>, TCredentials) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
Deprecated.
 
BlockCache - Interface in org.apache.accumulo.core.file.blockfile.cache
Block cache interface.
BlockedInputStream - Class in org.apache.accumulo.core.security.crypto
Reader corresponding to BlockedOutputStream.
BlockedInputStream(InputStream, int, int) - Constructor for class org.apache.accumulo.core.security.crypto.BlockedInputStream
 
BlockedOutputStream - Class in org.apache.accumulo.core.security.crypto
 
BlockedOutputStream(OutputStream, int, int) - Constructor for class org.apache.accumulo.core.security.crypto.BlockedOutputStream
 
BlockFileReader - Interface in org.apache.accumulo.core.file.blockfile
Provides a generic interface for a Reader for a BlockBaseFile format.
BlockFileWriter - Interface in org.apache.accumulo.core.file.blockfile
Provides a generic interface for a Writer for a BlockBaseFile format.
BlockIndex - Class in org.apache.accumulo.core.file.rfile
 
BlockIndex() - Constructor for class org.apache.accumulo.core.file.rfile.BlockIndex
 
BlockIndex.BlockIndexEntry - Class in org.apache.accumulo.core.file.rfile
 
BlockIndex.BlockIndexEntry(int, int, Key) - Constructor for class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
BlockIndex.BlockIndexEntry(Key) - Constructor for class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
BLOOM_FILE_NAME - Static variable in class org.apache.accumulo.core.file.BloomFilterLayer
 
BloomFilter - Class in org.apache.accumulo.core.bloomfilter
Implements a Bloom filter, as defined by Bloom in 1970.
BloomFilter() - Constructor for class org.apache.accumulo.core.bloomfilter.BloomFilter
Default constructor - use with readFields
BloomFilter(int, int, int) - Constructor for class org.apache.accumulo.core.bloomfilter.BloomFilter
Constructor
BloomFilterLayer - Class in org.apache.accumulo.core.file
A class that sits on top of different accumulo file formats and provides bloom filter functionality.
BloomFilterLayer() - Constructor for class org.apache.accumulo.core.file.BloomFilterLayer
 
BloomFilterLayer.Reader - Class in org.apache.accumulo.core.file
 
BloomFilterLayer.Reader(FileSKVIterator, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
BloomFilterLayer.Writer - Class in org.apache.accumulo.core.file
 
bound(Column, Column) - Method in class org.apache.accumulo.core.data.Range
Creates a new range that is bounded by the columns passed in.
buffer() - Method in class org.apache.accumulo.core.file.rfile.bcfile.ByteArray
 
buffer() - Method in interface org.apache.accumulo.core.file.rfile.bcfile.RawComparable
Get the underlying byte array.
bufferForCf() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
bufferForColFamily() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
bufferForColQualifier() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
bufferForColumnFamily() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
bufferForColumnQualifier() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
bufferForColumnVisibility() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
bufferForColVisibility() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
bufferForCq() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
bufferForCv() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
bufferForData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
bufferForEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
bufferForEndRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
bufferForEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
bufferForEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
bufferForIterators() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
bufferForPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
bufferForPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
bufferForPrevEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
bufferForRow() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
bufferForRow() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
bufferForSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
bufferForStartRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
bufferForStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
bufferForStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
bufferForTable() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
bufferForToken() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
bufferForVal() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
bufferForValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
buildDocKey() - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
buildFollowingPartitionKey(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
buildKey(Text, Text, Text) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
buildKey(Text, Text) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
buildKey(Text, Text) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
buildKey(Text, Text, Text) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
BULK_ARBITRATOR_TYPE - Static variable in class org.apache.accumulo.core.Constants
 
BULK_PREFIX - Static variable in class org.apache.accumulo.core.Constants
 
bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
BulkImportHelper - Class in org.apache.accumulo.core.util
 
BulkImportHelper() - Constructor for class org.apache.accumulo.core.util.BulkImportHelper
 
BulkImportHelper.AssignmentStats - Class in org.apache.accumulo.core.util
 
BulkImportHelper.AssignmentStats() - Constructor for class org.apache.accumulo.core.util.BulkImportHelper.AssignmentStats
 
ByeCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ByeCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ByeCommand
 
BYTE_BUFFER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for ByteBuffer
ByteArray - Class in org.apache.accumulo.core.file.rfile.bcfile
Adaptor class to wrap byte-array backed objects (including java byte array) as RawComparable objects.
ByteArray(BytesWritable) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.ByteArray
Constructing a ByteArray from a BytesWritable.
ByteArray(byte[]) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.ByteArray
Wrap a whole byte array as a RawComparable.
ByteArray(byte[], int, int) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.ByteArray
Wrap a partial byte array as a RawComparable.
ByteArrayBackedCharSequence - Class in org.apache.accumulo.core.util
 
ByteArrayBackedCharSequence(byte[], int, int) - Constructor for class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
ByteArrayBackedCharSequence(byte[]) - Constructor for class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
ByteArrayBackedCharSequence() - Constructor for class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
ByteArrayComparator - Class in org.apache.accumulo.core.util
 
ByteArrayComparator() - Constructor for class org.apache.accumulo.core.util.ByteArrayComparator
 
ByteArraySet - Class in org.apache.accumulo.core.util
 
ByteArraySet() - Constructor for class org.apache.accumulo.core.util.ByteArraySet
 
ByteArraySet(Collection<? extends byte[]>) - Constructor for class org.apache.accumulo.core.util.ByteArraySet
 
byteAt(int) - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
byteAt(int) - Method in class org.apache.accumulo.core.data.ByteSequence
 
ByteBufferUtil - Class in org.apache.accumulo.core.util
 
ByteBufferUtil() - Constructor for class org.apache.accumulo.core.util.ByteBufferUtil
 
ByteSequence - Class in org.apache.accumulo.core.data
 
ByteSequence() - Constructor for class org.apache.accumulo.core.data.ByteSequence
 
BytesLexicoder - Class in org.apache.accumulo.core.client.lexicoder
For each of the methods, this lexicoder just passes the input through untouched.
BytesLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
 
bytesToLong(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
Deprecated.
 
bytesToLong(byte[], int) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
Deprecated.
 
bytesToLong(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
Deprecated.
 
bytesToLongArray(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
Deprecated.
 
ByteUtils - Class in org.apache.accumulo.core.client.lexicoder.impl
 
ByteUtils() - Constructor for class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
 

C

CachableBlockFile - Class in org.apache.accumulo.core.file.blockfile.impl
This is a wrapper class for BCFile that includes a cache for independent caches for datablocks and metadatablocks
CachableBlockFile.BlockRead - Class in org.apache.accumulo.core.file.blockfile.impl
Class provides functionality to read one block from the underlying BCFile Since We are caching blocks in the Reader class as bytearrays, this class will wrap a DataInputStream(ByteArrayStream(cachedBlock)).
CachableBlockFile.BlockRead(InputStream, long) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
 
CachableBlockFile.BlockWrite - Class in org.apache.accumulo.core.file.blockfile.impl
 
CachableBlockFile.BlockWrite(BCFile.Writer.BlockAppender) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
 
CachableBlockFile.CachedBlockRead - Class in org.apache.accumulo.core.file.blockfile.impl
 
CachableBlockFile.CachedBlockRead(CacheEntry, byte[]) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
CachableBlockFile.Reader - Class in org.apache.accumulo.core.file.blockfile.impl
Class wraps the BCFile reader.
CachableBlockFile.Reader(FileSystem, Path, Configuration, BlockCache, BlockCache, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
CachableBlockFile.Reader(FSDataInputStream, long, Configuration, BlockCache, BlockCache, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
CachableBlockFile.Reader(FSDataInputStream, long, Configuration, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
CachableBlockFile.Writer - Class in org.apache.accumulo.core.file.blockfile.impl
 
CachableBlockFile.Writer(FileSystem, Path, String, Configuration, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
 
CachableBlockFile.Writer(FSDataOutputStream, String, Configuration, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
 
cache - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
CACHE_FIXED_OVERHEAD - Static variable in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
cacheBlock(String, byte[], boolean) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
Add block to cache.
cacheBlock(String, byte[]) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
Add block to cache (defaults to not in-memory).
cacheBlock(String, byte[], boolean) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
 
cacheBlock(String, byte[], boolean) - Method in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
 
CachedBlock - Class in org.apache.accumulo.core.file.blockfile.cache
Represents an entry in the LruBlockCache.
CachedBlock(String, byte[], long) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
CachedBlock(String, byte[], long, boolean) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
CachedBlockQueue - Class in org.apache.accumulo.core.file.blockfile.cache
A memory-bound queue that will grow until an element brings total size >= maxSize.
CachedBlockQueue(long, long) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
 
cachedClientConfig - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
CachedConfiguration - Class in org.apache.accumulo.core.util
 
CachedConfiguration() - Constructor for class org.apache.accumulo.core.util.CachedConfiguration
 
cachedInstance - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
CacheEntry - Interface in org.apache.accumulo.core.file.blockfile.cache
 
cacheMetaBlock(String, BCFile.Reader.BlockReader) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
cacheMetaBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
CachingHDFSSecretKeyEncryptionStrategy - Class in org.apache.accumulo.core.security.crypto
A SecretKeyEncryptionStrategy that gets its key from HDFS and caches it for IO.
CachingHDFSSecretKeyEncryptionStrategy() - Constructor for class org.apache.accumulo.core.security.crypto.CachingHDFSSecretKeyEncryptionStrategy
 
calculateOverhead(long, long, int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
cancelCompaction(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
cancelCompaction(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
canCreateTables(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Determines whether tables are permitted to be created as needed.
canCreateTables(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Determines whether tables are permitted to be created as needed.
canCreateTables(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
Determines whether tables are permitted to be created as needed.
canCreateTables(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
candidates - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
canSee(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates whether or not the user is able to see key.
canSeeColumnFamily(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates whether or not key can be seen, according to the fetched column families for this iterator.
cf - Variable in class org.apache.accumulo.core.data.thrift.TCondition
 
changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
changeLocalUserPassword(String, PasswordToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Set the user's password
changeLocalUserPassword(String, PasswordToken) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
changeUserAuthorizations(String, Authorizations) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Set the user's record-level authorizations
changeUserAuthorizations(String, Authorizations) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
changeUserPassword(String, byte[]) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Deprecated.
since 1.5.0; use SecurityOperations.changeLocalUserPassword(String, PasswordToken) or the user management functions of your configured authenticator instead.
changeUserPassword(String, byte[]) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
Deprecated.
charAt(int) - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
CHARSET - Static variable in class org.apache.accumulo.core.util.shell.Shell
 
check(Constraint.Environment, Mutation) - Method in interface org.apache.accumulo.core.constraints.Constraint
Checks a mutation for constrain violations.
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
 
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.security.VisibilityConstraint
 
checkClass(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
checkClass(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
checkClass(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
checkClass(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.
checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.
checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
checkNamespaceClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
checkNamespaceClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
checkState(boolean) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
checkTableClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
checkTableClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
checkTableClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
checkTableClass(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
checkTableState() - Method in class org.apache.accumulo.core.util.shell.Shell
 
chop(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
chop(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
chop(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
chop(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
CHOPPED_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ChoppedColumnFamily
 
CLASS - Static variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
 
CLASS - Static variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
 
CLASS_PREFIX - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
className - Variable in class org.apache.accumulo.core.data.thrift.IterInfo
 
ClasspathCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ClasspathCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ClasspathCommand
 
ClassSize - Class in org.apache.accumulo.core.file.blockfile.cache
Class for determining the "size" of a class, an attempt to calculate the actual bytes that an object of this class will occupy in memory The core of this class is taken from the Derby project
ClassSize() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.ClassSize
 
CleanUp - Class in org.apache.accumulo.core.util
 
CleanUp() - Constructor for class org.apache.accumulo.core.util.CleanUp
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
clear() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
clear() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
clear() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
 
clear() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
clear() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
method here to support testing, do not call
clear() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
clear() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
clear() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
clear() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
clear() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
clear() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
clear() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
clear() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
clear() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
clear() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
clear() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
clear() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
clear() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
 
clear() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
clear() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
clear() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
clear() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
clear() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
clear() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
clear() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
clear() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
clear() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
clear() - Method in class org.apache.accumulo.core.util.Stat
 
clearAndNull() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
method here to support testing, do not call
clearCache(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
clearColumns() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
clearColumns() - Method in interface org.apache.accumulo.core.client.ScannerBase
Clears the columns to be fetched (useful for resetting the scanner for reuse).
ClearCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ClearCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ClearCommand
 
clearInstance() - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
method here to support testing, do not call
clearLocatorCache(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Clears the tablet locator cache for a specified table
clearLocatorCache(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Clears the tablet locator cache for a specified table
clearLocators() - Static method in class org.apache.accumulo.core.client.impl.TabletLocator
 
clearOptions() - Method in class org.apache.accumulo.core.client.IteratorSetting
Remove all options from the iterator.
clearScanIterators() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Clears scan iterators prior to returning a scanner to the pool.
clearScanIterators() - Method in interface org.apache.accumulo.core.client.ScannerBase
Clears scan iterators prior to returning a scanner to the pool.
client - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
clientConfigFile - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
ClientConfiguration - Class in org.apache.accumulo.core.client
Contains a list of property keys recognized by the Accumulo client and convenience methods for setting them.
ClientConfiguration(List<? extends Configuration>) - Constructor for class org.apache.accumulo.core.client.ClientConfiguration
 
ClientConfiguration(Configuration...) - Constructor for class org.apache.accumulo.core.client.ClientConfiguration
Iterates through the Configuration objects, populating this object.
ClientConfiguration.ClientProperty - Enum in org.apache.accumulo.core.client
 
ClientExec<T> - Interface in org.apache.accumulo.core.client.impl
 
ClientExecReturn<T,C> - Interface in org.apache.accumulo.core.client.impl
 
ClientOnDefaultTable - Class in org.apache.accumulo.core.cli
 
ClientOnDefaultTable(String) - Constructor for class org.apache.accumulo.core.cli.ClientOnDefaultTable
 
ClientOnRequiredTable - Class in org.apache.accumulo.core.cli
 
ClientOnRequiredTable() - Constructor for class org.apache.accumulo.core.cli.ClientOnRequiredTable
 
ClientOpts - Class in org.apache.accumulo.core.cli
 
ClientOpts() - Constructor for class org.apache.accumulo.core.cli.ClientOpts
 
ClientOpts.AuthConverter - Class in org.apache.accumulo.core.cli
 
ClientOpts.AuthConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.AuthConverter
 
ClientOpts.MemoryConverter - Class in org.apache.accumulo.core.cli
 
ClientOpts.MemoryConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.MemoryConverter
 
ClientOpts.Password - Class in org.apache.accumulo.core.cli
 
ClientOpts.Password(String) - Constructor for class org.apache.accumulo.core.cli.ClientOpts.Password
 
ClientOpts.PasswordConverter - Class in org.apache.accumulo.core.cli
 
ClientOpts.PasswordConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.PasswordConverter
 
ClientOpts.TimeConverter - Class in org.apache.accumulo.core.cli
 
ClientOpts.TimeConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.TimeConverter
 
ClientOpts.VisibilityConverter - Class in org.apache.accumulo.core.cli
 
ClientOpts.VisibilityConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.VisibilityConverter
 
ClientService - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService
 
ClientService.AsyncClient - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
ClientService.AsyncClient.authenticate_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.authenticate_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticate_call
 
ClientService.AsyncClient.authenticateUser_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.authenticateUser_call(TInfo, TCredentials, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticateUser_call
 
ClientService.AsyncClient.bulkImportFiles_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.bulkImportFiles_call(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.bulkImportFiles_call
 
ClientService.AsyncClient.changeAuthorizations_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.changeAuthorizations_call(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeAuthorizations_call
 
ClientService.AsyncClient.changeLocalUserPassword_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.changeLocalUserPassword_call(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
 
ClientService.AsyncClient.checkClass_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.checkClass_call(TInfo, TCredentials, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkClass_call
 
ClientService.AsyncClient.checkNamespaceClass_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.checkNamespaceClass_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
 
ClientService.AsyncClient.checkTableClass_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.checkTableClass_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkTableClass_call
 
ClientService.AsyncClient.createLocalUser_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.createLocalUser_call(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.createLocalUser_call
 
ClientService.AsyncClient.dropLocalUser_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.dropLocalUser_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.dropLocalUser_call
 
ClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.Factory
 
ClientService.AsyncClient.getConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.getConfiguration_call(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getConfiguration_call
 
ClientService.AsyncClient.getDiskUsage_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.getDiskUsage_call(Set<String>, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getDiskUsage_call
 
ClientService.AsyncClient.getInstanceId_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.getInstanceId_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getInstanceId_call
 
ClientService.AsyncClient.getNamespaceConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.getNamespaceConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
 
ClientService.AsyncClient.getRootTabletLocation_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.getRootTabletLocation_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
 
ClientService.AsyncClient.getTableConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.getTableConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getTableConfiguration_call
 
ClientService.AsyncClient.getUserAuthorizations_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.getUserAuthorizations_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
 
ClientService.AsyncClient.getZooKeepers_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.getZooKeepers_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getZooKeepers_call
 
ClientService.AsyncClient.grantNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.grantNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
 
ClientService.AsyncClient.grantSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.grantSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantSystemPermission_call
 
ClientService.AsyncClient.grantTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.grantTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantTablePermission_call
 
ClientService.AsyncClient.hasNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.hasNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
 
ClientService.AsyncClient.hasSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.hasSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasSystemPermission_call
 
ClientService.AsyncClient.hasTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.hasTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasTablePermission_call
 
ClientService.AsyncClient.isActive_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.isActive_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.isActive_call
 
ClientService.AsyncClient.listLocalUsers_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.listLocalUsers_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.listLocalUsers_call
 
ClientService.AsyncClient.ping_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.ping_call(TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.ping_call
 
ClientService.AsyncClient.revokeNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.revokeNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
 
ClientService.AsyncClient.revokeSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.revokeSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
 
ClientService.AsyncClient.revokeTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncClient.revokeTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeTablePermission_call
 
ClientService.AsyncIface - Interface in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor
 
ClientService.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor
 
ClientService.AsyncProcessor.authenticate<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.authenticate() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
 
ClientService.AsyncProcessor.authenticateUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.authenticateUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
 
ClientService.AsyncProcessor.bulkImportFiles<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.bulkImportFiles() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
 
ClientService.AsyncProcessor.changeAuthorizations<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.changeAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
ClientService.AsyncProcessor.changeLocalUserPassword<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.changeLocalUserPassword() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
ClientService.AsyncProcessor.checkClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.checkClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
 
ClientService.AsyncProcessor.checkNamespaceClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.checkNamespaceClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
ClientService.AsyncProcessor.checkTableClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.checkTableClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
 
ClientService.AsyncProcessor.createLocalUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.createLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
 
ClientService.AsyncProcessor.dropLocalUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.dropLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
ClientService.AsyncProcessor.getConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.getConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
 
ClientService.AsyncProcessor.getDiskUsage<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.getDiskUsage() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
ClientService.AsyncProcessor.getInstanceId<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.getInstanceId() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
 
ClientService.AsyncProcessor.getNamespaceConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
ClientService.AsyncProcessor.getRootTabletLocation<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.getRootTabletLocation() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
ClientService.AsyncProcessor.getTableConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.getTableConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
ClientService.AsyncProcessor.getUserAuthorizations<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.getUserAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
ClientService.AsyncProcessor.getZooKeepers<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.getZooKeepers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
ClientService.AsyncProcessor.grantNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.grantNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
ClientService.AsyncProcessor.grantSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.grantSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
ClientService.AsyncProcessor.grantTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.grantTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
ClientService.AsyncProcessor.hasNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.hasNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
ClientService.AsyncProcessor.hasSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.hasSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
ClientService.AsyncProcessor.hasTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.hasTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
ClientService.AsyncProcessor.isActive<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.isActive() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
 
ClientService.AsyncProcessor.listLocalUsers<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.listLocalUsers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
ClientService.AsyncProcessor.ping<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.ping() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
 
ClientService.AsyncProcessor.revokeNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.revokeNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
ClientService.AsyncProcessor.revokeSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.revokeSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
ClientService.AsyncProcessor.revokeTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.AsyncProcessor.revokeTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
ClientService.authenticate_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.authenticate_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
ClientService.authenticate_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
ClientService.authenticate_args(ClientService.authenticate_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
Performs a deep copy on other.
ClientService.authenticate_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.authenticate_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.authenticate_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
ClientService.authenticate_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
ClientService.authenticate_result(ClientService.authenticate_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
Performs a deep copy on other.
ClientService.authenticate_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.authenticateUser_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.authenticateUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
ClientService.authenticateUser_args(TInfo, TCredentials, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
ClientService.authenticateUser_args(ClientService.authenticateUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
Performs a deep copy on other.
ClientService.authenticateUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.authenticateUser_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.authenticateUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
ClientService.authenticateUser_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
ClientService.authenticateUser_result(ClientService.authenticateUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
Performs a deep copy on other.
ClientService.authenticateUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.bulkImportFiles_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.bulkImportFiles_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
ClientService.bulkImportFiles_args(TInfo, TCredentials, long, String, List<String>, String, boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
ClientService.bulkImportFiles_args(ClientService.bulkImportFiles_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Performs a deep copy on other.
ClientService.bulkImportFiles_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.bulkImportFiles_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.bulkImportFiles_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
ClientService.bulkImportFiles_result(List<String>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
ClientService.bulkImportFiles_result(ClientService.bulkImportFiles_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
Performs a deep copy on other.
ClientService.bulkImportFiles_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.changeAuthorizations_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.changeAuthorizations_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
ClientService.changeAuthorizations_args(TInfo, TCredentials, String, List<ByteBuffer>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
ClientService.changeAuthorizations_args(ClientService.changeAuthorizations_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
Performs a deep copy on other.
ClientService.changeAuthorizations_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.changeAuthorizations_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.changeAuthorizations_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
ClientService.changeAuthorizations_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
ClientService.changeAuthorizations_result(ClientService.changeAuthorizations_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
Performs a deep copy on other.
ClientService.changeAuthorizations_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.changeLocalUserPassword_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.changeLocalUserPassword_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
ClientService.changeLocalUserPassword_args(TInfo, TCredentials, String, ByteBuffer) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
ClientService.changeLocalUserPassword_args(ClientService.changeLocalUserPassword_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
Performs a deep copy on other.
ClientService.changeLocalUserPassword_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.changeLocalUserPassword_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.changeLocalUserPassword_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
ClientService.changeLocalUserPassword_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
ClientService.changeLocalUserPassword_result(ClientService.changeLocalUserPassword_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
Performs a deep copy on other.
ClientService.changeLocalUserPassword_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkClass_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.checkClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
ClientService.checkClass_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
ClientService.checkClass_args(ClientService.checkClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
Performs a deep copy on other.
ClientService.checkClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkClass_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.checkClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
ClientService.checkClass_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
ClientService.checkClass_result(ClientService.checkClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
Performs a deep copy on other.
ClientService.checkClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkNamespaceClass_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.checkNamespaceClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
ClientService.checkNamespaceClass_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
ClientService.checkNamespaceClass_args(ClientService.checkNamespaceClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
Performs a deep copy on other.
ClientService.checkNamespaceClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkNamespaceClass_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.checkNamespaceClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
ClientService.checkNamespaceClass_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
ClientService.checkNamespaceClass_result(ClientService.checkNamespaceClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
Performs a deep copy on other.
ClientService.checkNamespaceClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkTableClass_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.checkTableClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
ClientService.checkTableClass_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
ClientService.checkTableClass_args(ClientService.checkTableClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
Performs a deep copy on other.
ClientService.checkTableClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkTableClass_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.checkTableClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
ClientService.checkTableClass_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
ClientService.checkTableClass_result(ClientService.checkTableClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
Performs a deep copy on other.
ClientService.checkTableClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.Client - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Client(TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
ClientService.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
ClientService.Client.Factory - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Client.Factory() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client.Factory
 
ClientService.createLocalUser_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.createLocalUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
ClientService.createLocalUser_args(TInfo, TCredentials, String, ByteBuffer) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
ClientService.createLocalUser_args(ClientService.createLocalUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
Performs a deep copy on other.
ClientService.createLocalUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.createLocalUser_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.createLocalUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
ClientService.createLocalUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
ClientService.createLocalUser_result(ClientService.createLocalUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
Performs a deep copy on other.
ClientService.createLocalUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.dropLocalUser_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.dropLocalUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
ClientService.dropLocalUser_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
ClientService.dropLocalUser_args(ClientService.dropLocalUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
Performs a deep copy on other.
ClientService.dropLocalUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.dropLocalUser_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.dropLocalUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
ClientService.dropLocalUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
ClientService.dropLocalUser_result(ClientService.dropLocalUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
Performs a deep copy on other.
ClientService.dropLocalUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
ClientService.getConfiguration_args(TInfo, TCredentials, ConfigurationType) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
ClientService.getConfiguration_args(ClientService.getConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
Performs a deep copy on other.
ClientService.getConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
ClientService.getConfiguration_result(Map<String, String>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
ClientService.getConfiguration_result(ClientService.getConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
Performs a deep copy on other.
ClientService.getConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getDiskUsage_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getDiskUsage_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
ClientService.getDiskUsage_args(Set<String>, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
ClientService.getDiskUsage_args(ClientService.getDiskUsage_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
Performs a deep copy on other.
ClientService.getDiskUsage_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getDiskUsage_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getDiskUsage_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
ClientService.getDiskUsage_result(List<TDiskUsage>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
ClientService.getDiskUsage_result(ClientService.getDiskUsage_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
Performs a deep copy on other.
ClientService.getDiskUsage_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getInstanceId_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getInstanceId_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
ClientService.getInstanceId_args(ClientService.getInstanceId_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
Performs a deep copy on other.
ClientService.getInstanceId_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getInstanceId_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getInstanceId_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
ClientService.getInstanceId_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
ClientService.getInstanceId_result(ClientService.getInstanceId_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
Performs a deep copy on other.
ClientService.getInstanceId_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getNamespaceConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getNamespaceConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
ClientService.getNamespaceConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
ClientService.getNamespaceConfiguration_args(ClientService.getNamespaceConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
Performs a deep copy on other.
ClientService.getNamespaceConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getNamespaceConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getNamespaceConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
ClientService.getNamespaceConfiguration_result(Map<String, String>, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
ClientService.getNamespaceConfiguration_result(ClientService.getNamespaceConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
Performs a deep copy on other.
ClientService.getNamespaceConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getRootTabletLocation_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getRootTabletLocation_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
ClientService.getRootTabletLocation_args(ClientService.getRootTabletLocation_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
Performs a deep copy on other.
ClientService.getRootTabletLocation_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getRootTabletLocation_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getRootTabletLocation_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
ClientService.getRootTabletLocation_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
ClientService.getRootTabletLocation_result(ClientService.getRootTabletLocation_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
Performs a deep copy on other.
ClientService.getRootTabletLocation_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getTableConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getTableConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
ClientService.getTableConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
ClientService.getTableConfiguration_args(ClientService.getTableConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
Performs a deep copy on other.
ClientService.getTableConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getTableConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getTableConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
ClientService.getTableConfiguration_result(Map<String, String>, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
ClientService.getTableConfiguration_result(ClientService.getTableConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
Performs a deep copy on other.
ClientService.getTableConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getUserAuthorizations_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getUserAuthorizations_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
ClientService.getUserAuthorizations_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
ClientService.getUserAuthorizations_args(ClientService.getUserAuthorizations_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
Performs a deep copy on other.
ClientService.getUserAuthorizations_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getUserAuthorizations_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getUserAuthorizations_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
ClientService.getUserAuthorizations_result(List<ByteBuffer>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
ClientService.getUserAuthorizations_result(ClientService.getUserAuthorizations_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
Performs a deep copy on other.
ClientService.getUserAuthorizations_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getZooKeepers_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getZooKeepers_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
ClientService.getZooKeepers_args(ClientService.getZooKeepers_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
Performs a deep copy on other.
ClientService.getZooKeepers_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getZooKeepers_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.getZooKeepers_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
ClientService.getZooKeepers_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
ClientService.getZooKeepers_result(ClientService.getZooKeepers_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
Performs a deep copy on other.
ClientService.getZooKeepers_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.grantNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.grantNamespacePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
ClientService.grantNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
ClientService.grantNamespacePermission_args(ClientService.grantNamespacePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
Performs a deep copy on other.
ClientService.grantNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.grantNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.grantNamespacePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
ClientService.grantNamespacePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
ClientService.grantNamespacePermission_result(ClientService.grantNamespacePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
Performs a deep copy on other.
ClientService.grantNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.grantSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.grantSystemPermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
ClientService.grantSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
ClientService.grantSystemPermission_args(ClientService.grantSystemPermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
Performs a deep copy on other.
ClientService.grantSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.grantSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.grantSystemPermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
ClientService.grantSystemPermission_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
ClientService.grantSystemPermission_result(ClientService.grantSystemPermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
Performs a deep copy on other.
ClientService.grantSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.grantTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.grantTablePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
ClientService.grantTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
ClientService.grantTablePermission_args(ClientService.grantTablePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Performs a deep copy on other.
ClientService.grantTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.grantTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.grantTablePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
ClientService.grantTablePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
ClientService.grantTablePermission_result(ClientService.grantTablePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
Performs a deep copy on other.
ClientService.grantTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.hasNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.hasNamespacePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
ClientService.hasNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
ClientService.hasNamespacePermission_args(ClientService.hasNamespacePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
Performs a deep copy on other.
ClientService.hasNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.hasNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.hasNamespacePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
ClientService.hasNamespacePermission_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
ClientService.hasNamespacePermission_result(ClientService.hasNamespacePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
Performs a deep copy on other.
ClientService.hasNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.hasSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.hasSystemPermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
ClientService.hasSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
ClientService.hasSystemPermission_args(ClientService.hasSystemPermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
Performs a deep copy on other.
ClientService.hasSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.hasSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.hasSystemPermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
ClientService.hasSystemPermission_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
ClientService.hasSystemPermission_result(ClientService.hasSystemPermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
Performs a deep copy on other.
ClientService.hasSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.hasTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.hasTablePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
ClientService.hasTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
ClientService.hasTablePermission_args(ClientService.hasTablePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Performs a deep copy on other.
ClientService.hasTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.hasTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.hasTablePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
ClientService.hasTablePermission_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
ClientService.hasTablePermission_result(ClientService.hasTablePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
Performs a deep copy on other.
ClientService.hasTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.Iface - Interface in org.apache.accumulo.core.client.impl.thrift
 
ClientService.isActive_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.isActive_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
ClientService.isActive_args(TInfo, long) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
ClientService.isActive_args(ClientService.isActive_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
Performs a deep copy on other.
ClientService.isActive_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.isActive_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.isActive_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
ClientService.isActive_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
ClientService.isActive_result(ClientService.isActive_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
Performs a deep copy on other.
ClientService.isActive_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.listLocalUsers_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.listLocalUsers_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
ClientService.listLocalUsers_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
ClientService.listLocalUsers_args(ClientService.listLocalUsers_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
Performs a deep copy on other.
ClientService.listLocalUsers_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.listLocalUsers_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.listLocalUsers_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
ClientService.listLocalUsers_result(Set<String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
ClientService.listLocalUsers_result(ClientService.listLocalUsers_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
Performs a deep copy on other.
ClientService.listLocalUsers_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.ping_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.ping_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
ClientService.ping_args(TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
ClientService.ping_args(ClientService.ping_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
Performs a deep copy on other.
ClientService.ping_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.ping_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.ping_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
ClientService.ping_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
ClientService.ping_result(ClientService.ping_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
Performs a deep copy on other.
ClientService.ping_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.Processor<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor(I) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor
 
ClientService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor
 
ClientService.Processor.authenticate<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.authenticate() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
 
ClientService.Processor.authenticateUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.authenticateUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
 
ClientService.Processor.bulkImportFiles<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.bulkImportFiles() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
 
ClientService.Processor.changeAuthorizations<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.changeAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
 
ClientService.Processor.changeLocalUserPassword<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.changeLocalUserPassword() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeLocalUserPassword
 
ClientService.Processor.checkClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.checkClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
 
ClientService.Processor.checkNamespaceClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.checkNamespaceClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
 
ClientService.Processor.checkTableClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.checkTableClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
 
ClientService.Processor.createLocalUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.createLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
 
ClientService.Processor.dropLocalUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.dropLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
 
ClientService.Processor.getConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.getConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
 
ClientService.Processor.getDiskUsage<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.getDiskUsage() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
 
ClientService.Processor.getInstanceId<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.getInstanceId() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
 
ClientService.Processor.getNamespaceConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
 
ClientService.Processor.getRootTabletLocation<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.getRootTabletLocation() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
 
ClientService.Processor.getTableConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.getTableConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
 
ClientService.Processor.getUserAuthorizations<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.getUserAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
 
ClientService.Processor.getZooKeepers<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.getZooKeepers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
 
ClientService.Processor.grantNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.grantNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
 
ClientService.Processor.grantSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.grantSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
 
ClientService.Processor.grantTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.grantTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
 
ClientService.Processor.hasNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.hasNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
 
ClientService.Processor.hasSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.hasSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
 
ClientService.Processor.hasTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.hasTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
 
ClientService.Processor.isActive<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.isActive() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
 
ClientService.Processor.listLocalUsers<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.listLocalUsers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
 
ClientService.Processor.ping<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.ping() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ping
 
ClientService.Processor.revokeNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.revokeNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeNamespacePermission
 
ClientService.Processor.revokeSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.revokeSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeSystemPermission
 
ClientService.Processor.revokeTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor.revokeTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeTablePermission
 
ClientService.revokeNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.revokeNamespacePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
ClientService.revokeNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
ClientService.revokeNamespacePermission_args(ClientService.revokeNamespacePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
Performs a deep copy on other.
ClientService.revokeNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.revokeNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.revokeNamespacePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
ClientService.revokeNamespacePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
ClientService.revokeNamespacePermission_result(ClientService.revokeNamespacePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
Performs a deep copy on other.
ClientService.revokeNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.revokeSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.revokeSystemPermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
ClientService.revokeSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
ClientService.revokeSystemPermission_args(ClientService.revokeSystemPermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
Performs a deep copy on other.
ClientService.revokeSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.revokeSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.revokeSystemPermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
ClientService.revokeSystemPermission_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
ClientService.revokeSystemPermission_result(ClientService.revokeSystemPermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
Performs a deep copy on other.
ClientService.revokeSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.revokeTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.revokeTablePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
ClientService.revokeTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
ClientService.revokeTablePermission_args(ClientService.revokeTablePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Performs a deep copy on other.
ClientService.revokeTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.revokeTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.revokeTablePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
ClientService.revokeTablePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
ClientService.revokeTablePermission_result(ClientService.revokeTablePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
Performs a deep copy on other.
ClientService.revokeTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientSideIteratorScanner - Class in org.apache.accumulo.core.client
A scanner that instantiates iterators on the client side instead of on the tablet server.
ClientSideIteratorScanner(Scanner) - Constructor for class org.apache.accumulo.core.client.ClientSideIteratorScanner
Constructs a scanner that can execute client-side iterators.
ClientSideIteratorScanner.ScannerTranslator - Class in org.apache.accumulo.core.client
A class that wraps a Scanner in a SortedKeyValueIterator so that other accumulo iterators can use it as a source.
ClientSideIteratorScanner.ScannerTranslator(Scanner) - Constructor for class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
Constructs an accumulo iterator from a scanner.
clip(Range) - Method in class org.apache.accumulo.core.data.Range
Creates a range which represents the intersection of this range and the passed in range.
clip(Range, boolean) - Method in class org.apache.accumulo.core.data.Range
Same as other clip function except if gives the option to return null of the ranges do not overlap instead of throwing an exception.
clone(String, String, boolean, Map<String, String>, Set<String>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Clone a table from an existing table.
clone(String, String, boolean, Map<String, String>, Set<String>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
clone() - Method in interface org.apache.accumulo.core.client.security.tokens.AuthenticationToken
 
clone() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
clone() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
clone() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
clone() - Method in class org.apache.accumulo.core.data.Key
 
CLONE_EXCLUDE_PREFIX - Static variable in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
CLONE_PREFIX - Static variable in class org.apache.accumulo.core.Constants
 
CLONE_PREFIX_BYTES - Static variable in class org.apache.accumulo.core.Constants
 
CloneTableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
CloneTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CloneTableCommand
 
close() - Method in interface org.apache.accumulo.core.client.BatchDeleter
Releases any resources.
close() - Method in interface org.apache.accumulo.core.client.BatchScanner
Cleans up and finalizes the scanner
close() - Method in interface org.apache.accumulo.core.client.BatchWriter
Flush and release any resources.
close() - Method in interface org.apache.accumulo.core.client.ConditionalWriter
release any resources (like threads pools) used by conditional writer
close() - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
 
close(MasterClientService.Iface) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
close() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
close() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
close(ClientService.Client) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
close() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
 
close() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
 
close() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
 
close(Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
 
close() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
 
close(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
 
close() - Method in class org.apache.accumulo.core.client.mock.MockBatchScanner
 
close() - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
 
close() - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
 
close() - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
Flush and release all resources.
close() - Method in interface org.apache.accumulo.core.client.ScannerBase
Closes any underlying connections on the scanner
close() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
 
close() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
 
close() - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
 
close() - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileWriter
 
close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
 
close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
 
close() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
close() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
close() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
close() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Finishing reading the block.
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Finishing reading the BCFile.
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
Signaling the end of write to the block.
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Close the BCFile Writer.
close(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
 
close(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Writer
 
close() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
close() - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
close() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
close() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
close() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
 
close() - Method in class org.apache.accumulo.core.security.crypto.BlockedOutputStream
 
close() - Method in class org.apache.accumulo.core.security.crypto.DiscardCloseOutputStream
 
close() - Method in class org.apache.accumulo.core.util.shell.Shell.PrintFile
 
close() - Method in interface org.apache.accumulo.core.util.shell.Shell.PrintLine
 
close() - Method in class org.apache.accumulo.core.util.shell.Shell.PrintShell
 
closeConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
closeConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
closeConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
closeConditionalUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
closeDeepCopies() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
closeDeepCopies() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
closeDeepCopies() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
closeDeepCopies() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
closeDeepCopies() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
closeDeepCopies() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
closeMultiScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
closeMultiScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
closeMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
closeMultiScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
closeScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
closeScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
closeScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
closeScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
closeUpdate(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
closeUpdate(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
closeUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
closeUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
ClsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ClsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ClsCommand
 
cmid - Variable in class org.apache.accumulo.core.data.thrift.TCMResult
 
code - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
COLF_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
colFamily - Variable in class org.apache.accumulo.core.data.Key
 
colFamily - Variable in class org.apache.accumulo.core.data.thrift.TKey
 
colFamSet - Variable in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
collect(Value) - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
Deprecated.
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
Deprecated.
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
Deprecated.
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
Deprecated.
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
Deprecated.
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
Deprecated.
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
Deprecated.
 
COLQ_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
colQualifier - Variable in class org.apache.accumulo.core.data.Key
 
colQualifier - Variable in class org.apache.accumulo.core.data.thrift.TKey
 
Column - Class in org.apache.accumulo.core.data
 
Column() - Constructor for class org.apache.accumulo.core.data.Column
 
Column(byte[], byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Column
 
Column(TColumn) - Constructor for class org.apache.accumulo.core.data.Column
 
ColumnAgeOffFilter - Class in org.apache.accumulo.core.iterators.user
A filter that ages off key/value pairs based on the Key's column and timestamp.
ColumnAgeOffFilter() - Constructor for class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
ColumnAgeOffFilter.TTLSet - Class in org.apache.accumulo.core.iterators.user
 
ColumnAgeOffFilter.TTLSet(Map<String, String>) - Constructor for class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter.TTLSet
 
columnFamilies - Variable in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
 
columnFamily - Variable in class org.apache.accumulo.core.data.Column
 
columnFamily - Variable in class org.apache.accumulo.core.data.thrift.TColumn
 
ColumnFamilyCounter - Class in org.apache.accumulo.core.iterators
 
ColumnFamilyCounter() - Constructor for class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
ColumnFamilyFunctor - Class in org.apache.accumulo.core.file.keyfunctor
 
ColumnFamilyFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
 
ColumnFamilySkippingIterator - Class in org.apache.accumulo.core.iterators.system
 
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>, Set<ByteSequence>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
ColumnFQ - Class in org.apache.accumulo.core.util
 
ColumnFQ(Text, Text) - Constructor for class org.apache.accumulo.core.util.ColumnFQ
 
ColumnFQ(Key) - Constructor for class org.apache.accumulo.core.util.ColumnFQ
 
ColumnFQ(ColumnUpdate) - Constructor for class org.apache.accumulo.core.util.ColumnFQ
 
columnQualifier - Variable in class org.apache.accumulo.core.data.Column
 
columnQualifier - Variable in class org.apache.accumulo.core.data.thrift.TColumn
 
ColumnQualifierFilter - Class in org.apache.accumulo.core.iterators.system
 
ColumnQualifierFilter() - Constructor for class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
 
ColumnQualifierFilter(SortedKeyValueIterator<Key, Value>, Set<Column>) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
 
ColumnQualifierFilter(SortedKeyValueIterator<Key, Value>, HashSet<ByteSequence>, HashMap<ByteSequence, HashSet<ByteSequence>>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
 
ColumnQualifierFunctor - Class in org.apache.accumulo.core.file.keyfunctor
 
ColumnQualifierFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor
 
columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
COLUMNS_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
 
ColumnSet - Class in org.apache.accumulo.core.iterators.conf
 
ColumnSet() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnSet
 
ColumnSet(Collection<String>) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnSet
 
ColumnSliceFilter - Class in org.apache.accumulo.core.iterators.user
 
ColumnSliceFilter() - Constructor for class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
ColumnToClassMapping<K> - Class in org.apache.accumulo.core.iterators.conf
 
ColumnToClassMapping() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
ColumnToClassMapping(Map<String, String>, Class<? extends K>) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
ColumnToClassMapping(Map<String, String>, Class<? extends K>, String) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
ColumnUpdate - Class in org.apache.accumulo.core.data
A single column and value pair within a mutation
ColumnUpdate(byte[], byte[], byte[], boolean, long, boolean, byte[]) - Constructor for class org.apache.accumulo.core.data.ColumnUpdate
 
ColumnUtil - Class in org.apache.accumulo.core.iterators.conf
 
ColumnUtil() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnUtil
 
ColumnUtil.ColFamHashKey - Class in org.apache.accumulo.core.iterators.conf
 
ColumnUtil.ColHashKey - Class in org.apache.accumulo.core.iterators.conf
 
columnVisibility - Variable in class org.apache.accumulo.core.data.Column
 
columnVisibility - Variable in class org.apache.accumulo.core.data.thrift.TColumn
 
ColumnVisibility - Class in org.apache.accumulo.core.security
Validate the column visibility is a valid expression and set the visibility for a Mutation.
ColumnVisibility() - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Creates an empty visibility.
ColumnVisibility(String) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Creates a column visibility for a Mutation.
ColumnVisibility(Text) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Creates a column visibility for a Mutation.
ColumnVisibility(byte[]) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Creates a column visibility for a Mutation from a string already encoded in UTF-8 bytes.
ColumnVisibility.Node - Class in org.apache.accumulo.core.security
A node in the parse tree for a visibility expression.
ColumnVisibility.Node(ColumnVisibility.NodeType, int) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.Node
 
ColumnVisibility.Node(int, int) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.Node
 
ColumnVisibility.NodeComparator - Class in org.apache.accumulo.core.security
A node comparator.
ColumnVisibility.NodeComparator(byte[]) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.NodeComparator
Creates a new comparator.
ColumnVisibility.NodeType - Enum in org.apache.accumulo.core.security
The node types in a parse tree for a visibility expression.
colVisibility - Variable in class org.apache.accumulo.core.data.Key
 
colVisibility - Variable in class org.apache.accumulo.core.data.thrift.TKey
 
Combiner - Class in org.apache.accumulo.core.iterators
A SortedKeyValueIterator that combines the Values for different versions (timestamp) of a Key within a row into a single Value.
Combiner() - Constructor for class org.apache.accumulo.core.iterators.Combiner
 
Combiner.ValueIterator - Class in org.apache.accumulo.core.iterators
A Java Iterator that iterates over the Values for a given Key from a source SortedKeyValueIterator.
Combiner.ValueIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.Combiner.ValueIterator
Constructs an iterator over Values whose Keys are versions of the current topKey of the source SortedKeyValueIterator.
commandFactory - Variable in class org.apache.accumulo.core.util.shell.Shell
 
commandGrouping - Variable in class org.apache.accumulo.core.util.shell.Shell
 
COMMENT_PREFIX - Static variable in class org.apache.accumulo.core.util.shell.Shell
 
compact(String, Text, Text, boolean, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Starts a full major compaction of the tablets in the range (start, end].
compact(String, Text, Text, List<IteratorSetting>, boolean, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Starts a full major compaction of the tablets in the range (start, end].
compact(String, Text, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
compact(String, Text, Text, List<IteratorSetting>, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
COMPACT_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds compact IDs to enable waiting on a compaction to complete
CompactCommand - Class in org.apache.accumulo.core.util.shell.commands
 
CompactCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CompactCommand
 
Compacting - Class in org.apache.accumulo.core.master.thrift
 
Compacting() - Constructor for class org.apache.accumulo.core.master.thrift.Compacting
 
Compacting(int, int) - Constructor for class org.apache.accumulo.core.master.thrift.Compacting
 
Compacting(Compacting) - Constructor for class org.apache.accumulo.core.master.thrift.Compacting
Performs a deep copy on other.
Compacting._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionReason - Enum in org.apache.accumulo.core.tabletserver.thrift
 
CompactionType - Enum in org.apache.accumulo.core.tabletserver.thrift
 
ComparableBytes - Class in org.apache.accumulo.core.data
 
ComparableBytes(byte[]) - Constructor for class org.apache.accumulo.core.data.ComparableBytes
 
ComparablePair<A extends Comparable<A>,B extends Comparable<B>> - Class in org.apache.accumulo.core.util
 
ComparablePair(A, B) - Constructor for class org.apache.accumulo.core.util.ComparablePair
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.accumulo.core.data.Value.Comparator
 
compare(IterInfo, IterInfo) - Method in class org.apache.accumulo.core.iterators.IteratorUtil.IterInfoComparator
 
compare(ColumnVisibility.Node, ColumnVisibility.Node) - Method in class org.apache.accumulo.core.security.ColumnVisibility.NodeComparator
 
compare(byte[], byte[]) - Method in class org.apache.accumulo.core.util.ByteArrayComparator
 
compareBytes(ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.data.ByteSequence
 
compareColumnFamily(Text) - Method in class org.apache.accumulo.core.data.Key
Efficiently compare the the column family of a key w/o allocating a text object and copying the column qualifier into it.
compareColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
Efficiently compare the the column qualifier of a key w/o allocating a text object and copying the column qualifier into it.
compareRow(Text) - Method in class org.apache.accumulo.core.data.Key
Efficiently compare the the row of a key w/o allocating a text object and copying the row into it.
compareTo(TabletLocator.TabletLocation) - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
compareTo(ClientService.authenticate_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
compareTo(ClientService.authenticate_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
compareTo(ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
compareTo(ClientService.authenticateUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
compareTo(ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
compareTo(ClientService.bulkImportFiles_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
compareTo(ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
compareTo(ClientService.changeAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
compareTo(ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
compareTo(ClientService.changeLocalUserPassword_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
compareTo(ClientService.checkClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
compareTo(ClientService.checkClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
compareTo(ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
compareTo(ClientService.checkNamespaceClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
compareTo(ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
compareTo(ClientService.checkTableClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
compareTo(ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
compareTo(ClientService.createLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
compareTo(ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
compareTo(ClientService.dropLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
compareTo(ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
compareTo(ClientService.getConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
compareTo(ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
compareTo(ClientService.getDiskUsage_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
compareTo(ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
compareTo(ClientService.getInstanceId_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
compareTo(ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
compareTo(ClientService.getNamespaceConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
compareTo(ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
compareTo(ClientService.getRootTabletLocation_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
compareTo(ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
compareTo(ClientService.getTableConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
compareTo(ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
compareTo(ClientService.getUserAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
compareTo(ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
compareTo(ClientService.getZooKeepers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
compareTo(ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
compareTo(ClientService.grantNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
compareTo(ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
compareTo(ClientService.grantSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
compareTo(ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
compareTo(ClientService.grantTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
compareTo(ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
compareTo(ClientService.hasNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
compareTo(ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
compareTo(ClientService.hasSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
compareTo(ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
compareTo(ClientService.hasTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
compareTo(ClientService.isActive_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
compareTo(ClientService.isActive_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
compareTo(ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
compareTo(ClientService.listLocalUsers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
compareTo(ClientService.ping_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
compareTo(ClientService.ping_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
compareTo(ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
compareTo(ClientService.revokeNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
compareTo(ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
compareTo(ClientService.revokeSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
compareTo(ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
compareTo(ClientService.revokeTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
compareTo(TDiskUsage) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
compareTo(ThriftSecurityException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
compareTo(ThriftTableOperationException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
compareTo(ThriftTest.fails_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
compareTo(ThriftTest.fails_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
compareTo(ThriftTest.success_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
compareTo(ThriftTest.success_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
compareTo(ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
compareTo(ThriftTest.throwsError_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
compareTo(AuthenticationToken.TokenProperty) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
compareTo(ByteSequence) - Method in class org.apache.accumulo.core.data.ByteSequence
 
compareTo(Column) - Method in class org.apache.accumulo.core.data.Column
 
compareTo(Key, PartialKey) - Method in class org.apache.accumulo.core.data.Key
Compare elements of a key given by a PartialKey.
compareTo(Key) - Method in class org.apache.accumulo.core.data.Key
Compare all elements of a key.
compareTo(KeyExtent) - Method in class org.apache.accumulo.core.data.KeyExtent
Compares extents based on rows
compareTo(Range) - Method in class org.apache.accumulo.core.data.Range
Compares this range to another range.
compareTo(InitialMultiScan) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
compareTo(InitialScan) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
compareTo(IterInfo) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
compareTo(MapFileInfo) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
compareTo(MultiScanResult) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
compareTo(ScanResult) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
compareTo(TCMResult) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
compareTo(TColumn) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
compareTo(TCondition) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
compareTo(TConditionalMutation) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
compareTo(TConditionalSession) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
compareTo(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
compareTo(TKey) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
compareTo(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
compareTo(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
compareTo(TMutation) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
compareTo(TRange) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
compareTo(UpdateErrors) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
compareTo(Object) - Method in class org.apache.accumulo.core.data.Value
Define the sort order of the BytesWritable.
compareTo(byte[]) - Method in class org.apache.accumulo.core.data.Value
Compares the bytes in this object to the specified byte array
compareTo(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
compareTo(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Compare this version with another version.
compareTo(BlockIndex.BlockIndexEntry) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
compareTo(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
compareTo(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
compareTo(GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
compareTo(GCMonitorService.getStatus_result) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
compareTo(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
compareTo(OrIterator.TermSource) - Method in class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
compareTo(Compacting) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
compareTo(DeadServer) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
compareTo(FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
compareTo(FateService.beginFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
compareTo(FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
compareTo(FateService.executeFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
compareTo(FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
compareTo(FateService.finishFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
compareTo(FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
compareTo(FateService.waitForFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
compareTo(MasterClientService.getMasterStats_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
compareTo(MasterClientService.getMasterStats_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
compareTo(MasterClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
compareTo(MasterClientService.initiateFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
compareTo(MasterClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
compareTo(MasterClientService.removeNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
compareTo(MasterClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
compareTo(MasterClientService.removeSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
compareTo(MasterClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
compareTo(MasterClientService.removeTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
compareTo(MasterClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
compareTo(MasterClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
compareTo(MasterClientService.setMasterGoalState_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
compareTo(MasterClientService.setMasterGoalState_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
compareTo(MasterClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
compareTo(MasterClientService.setNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
compareTo(MasterClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
compareTo(MasterClientService.setSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
compareTo(MasterClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
compareTo(MasterClientService.setTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
compareTo(MasterClientService.shutdown_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
compareTo(MasterClientService.shutdown_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
compareTo(MasterClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
compareTo(MasterClientService.shutdownTabletServer_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
compareTo(MasterClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
compareTo(MasterClientService.waitForFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
compareTo(MasterMonitorInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
compareTo(RecoveryException) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
compareTo(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
compareTo(TableInfo) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
compareTo(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
compareTo(TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
compareTo(TCredentials) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
compareTo(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
compareTo(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
compareTo(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
compareTo(ConstraintViolationException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
compareTo(IteratorConfig) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
compareTo(NoSuchScanIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
compareTo(NotServingTabletException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
compareTo(TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
compareTo(TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
compareTo(TabletClientService.bulkImport_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
compareTo(TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
compareTo(TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
compareTo(TabletClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
compareTo(TabletClientService.closeMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
compareTo(TabletClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
compareTo(TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
compareTo(TabletClientService.closeUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
compareTo(TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
compareTo(TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
compareTo(TabletClientService.conditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
compareTo(TabletClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
compareTo(TabletClientService.continueMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
compareTo(TabletClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
compareTo(TabletClientService.continueScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
compareTo(TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
compareTo(TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
compareTo(TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
compareTo(TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
compareTo(TabletClientService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
compareTo(TabletClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
compareTo(TabletClientService.getActiveScans_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
compareTo(TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
compareTo(TabletClientService.getHistoricalStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
compareTo(TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
compareTo(TabletClientService.getTabletServerStatus_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
compareTo(TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
compareTo(TabletClientService.getTabletStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
compareTo(TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
compareTo(TabletClientService.halt_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
compareTo(TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
compareTo(TabletClientService.invalidateConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
compareTo(TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
compareTo(TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
compareTo(TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
compareTo(TabletClientService.splitTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
compareTo(TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
compareTo(TabletClientService.startConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
compareTo(TabletClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
compareTo(TabletClientService.startMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
compareTo(TabletClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
compareTo(TabletClientService.startScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
compareTo(TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
compareTo(TabletClientService.startUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
compareTo(TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
compareTo(TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
compareTo(TabletClientService.update_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
compareTo(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
compareTo(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
compareTo(TooManyFilesException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
compareTo(ColumnFQ) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
compareTo(ComparablePair<A, B>) - Method in class org.apache.accumulo.core.util.ComparablePair
 
compareTo(ServerServices) - Method in class org.apache.accumulo.core.util.ServerServices
 
compatibleWith(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Test compatibility.
complete(String, int, List) - Method in class org.apache.accumulo.core.util.shell.ShellCompletor
 
compress(IteratorSetting[]) - Method in class org.apache.accumulo.core.client.impl.CompressedIterators
 
compress(List<? extends KeyValue>) - Static method in class org.apache.accumulo.core.data.Key
Use this to compress a list of keys before sending them via thrift.
CompressedIterators - Class in org.apache.accumulo.core.client.impl
 
CompressedIterators() - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators
 
CompressedIterators(List<String>) - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators
 
CompressedIterators.IterConfig - Class in org.apache.accumulo.core.client.impl
 
CompressedIterators.IterConfig() - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators.IterConfig
 
Compression - Class in org.apache.accumulo.core.file.rfile.bcfile
Compression related stuff.
Compression.Algorithm - Enum in org.apache.accumulo.core.file.rfile.bcfile
Compression algorithms.
COMPRESSION_GZ - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
compression: gzip
COMPRESSION_LZO - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
compression: lzo
COMPRESSION_NONE - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
compression: none
COMPRESSION_SNAPPY - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
snappy codec
computeReseekRange(Range) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Possibly expand range to include everything for the key prefix we are working with.
concat(byte[]...) - Static method in class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
Concatenates byte arrays with 0x00 as a delimiter
CONCURRENT_HASHMAP - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for ConcurrentHashMap
CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for ConcurrentHashMap.Entry
CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for ConcurrentHashMap.Segment
CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for ConcurrentSkipListMap
CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for ConcurrentSkipListMap Entry
Condition - Class in org.apache.accumulo.core.data
Conditions that must be met on a particular column in a row.
Condition(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Condition
 
Condition(byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Condition
 
Condition(Text, Text) - Constructor for class org.apache.accumulo.core.data.Condition
 
Condition(ByteSequence, ByteSequence) - Constructor for class org.apache.accumulo.core.data.Condition
 
ConditionalMutation - Class in org.apache.accumulo.core.data
A Mutation that contains a list of conditions that must all be met before the mutation is applied.
ConditionalMutation(byte[], Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(byte[], int, int, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(Text, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(CharSequence, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(ByteSequence, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(ConditionalMutation) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
ConditionalWriter - Interface in org.apache.accumulo.core.client
ConditionalWriter provides the ability to do efficient, atomic read-modify-write operations on rows.
ConditionalWriter.Result - Class in org.apache.accumulo.core.client
 
ConditionalWriter.Result(ConditionalWriter.Status, ConditionalMutation, String) - Constructor for class org.apache.accumulo.core.client.ConditionalWriter.Result
 
ConditionalWriter.Result(Exception, ConditionalMutation, String) - Constructor for class org.apache.accumulo.core.client.ConditionalWriter.Result
 
ConditionalWriter.Status - Enum in org.apache.accumulo.core.client
 
ConditionalWriterConfig - Class in org.apache.accumulo.core.client
 
ConditionalWriterConfig() - Constructor for class org.apache.accumulo.core.client.ConditionalWriterConfig
 
conditions - Variable in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
conf - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
CONF_LZO_CLASS - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
CONF_SNAPPY_CLASS - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
config(String...) - Method in class org.apache.accumulo.core.client.mock.MockShell
 
config(String...) - Method in class org.apache.accumulo.core.util.shell.Shell
Configures the shell using the provided options.
ConfigCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ConfigCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ConfigCommand
 
ConfigSanityCheck - Class in org.apache.accumulo.core.conf
A utility class for checking over configuration entries.
ConfigSanityCheck() - Constructor for class org.apache.accumulo.core.conf.ConfigSanityCheck
 
ConfigSanityCheck.SanityCheckException - Exception in org.apache.accumulo.core.conf
The exception thrown when ConfigSanityCheck.validate(Iterable) fails.
ConfigSanityCheck.SanityCheckException(String) - Constructor for exception org.apache.accumulo.core.conf.ConfigSanityCheck.SanityCheckException
Creates a new exception with the given message.
ConfigurationCopy - Class in org.apache.accumulo.core.conf
 
ConfigurationCopy(Map<String, String>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
 
ConfigurationCopy(Iterable<Map.Entry<String, String>>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
 
ConfigurationCopy() - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
 
ConfigurationObserver - Interface in org.apache.accumulo.core.conf
 
ConfigurationType - Enum in org.apache.accumulo.core.client.impl.thrift
 
ConfiguratorBase - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
 
ConfiguratorBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
 
ConfiguratorBase - Class in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
ConfiguratorBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
 
ConfiguratorBase.ConnectorInfo - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
ConfiguratorBase.ConnectorInfo - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
ConfiguratorBase.GeneralOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
Configuration keys for general configuration options.
ConfiguratorBase.GeneralOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
ConfiguratorBase.InstanceOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
Configuration keys for Instance, ZooKeeperInstance, and MockInstance.
ConfiguratorBase.InstanceOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
ConfiguratorBase.TokenSource - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
 
Connector - Class in org.apache.accumulo.core.client
Connector connects to an Accumulo instance and allows the user to request readers and writers for the instance as well as various objects that permit administrative operations.
Connector() - Constructor for class org.apache.accumulo.core.client.Connector
 
ConnectorImpl - Class in org.apache.accumulo.core.client.impl
 
ConnectorImpl(Instance, Credentials) - Constructor for class org.apache.accumulo.core.client.impl.ConnectorImpl
 
Constants - Class in org.apache.accumulo.core
 
Constants() - Constructor for class org.apache.accumulo.core.Constants
 
constrainClass - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
constrainClass - Variable in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
Constraint - Interface in org.apache.accumulo.core.constraints
Accumulo uses Constraint objects to determine if mutations will be applied to a table.
Constraint.Environment - Interface in org.apache.accumulo.core.constraints
 
ConstraintCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ConstraintCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ConstraintCommand
 
ConstraintViolationException - Exception in org.apache.accumulo.core.tabletserver.thrift
 
ConstraintViolationException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
ConstraintViolationException(List<TConstraintViolationSummary>) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
ConstraintViolationException(ConstraintViolationException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
Performs a deep copy on other.
ConstraintViolationException._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ConstraintViolationSummary - Class in org.apache.accumulo.core.data
 
ConstraintViolationSummary(String, short, String, long) - Constructor for class org.apache.accumulo.core.data.ConstraintViolationSummary
 
ConstraintViolationSummary(TConstraintViolationSummary) - Constructor for class org.apache.accumulo.core.data.ConstraintViolationSummary
 
consume() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.SkippingIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
contains(ByteSequence) - Method in class org.apache.accumulo.core.data.KeyExtent
 
contains(BinaryComparable) - Method in class org.apache.accumulo.core.data.KeyExtent
 
contains(Key) - Method in class org.apache.accumulo.core.data.Range
 
contains(Key) - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
 
contains(ByteSequence) - Method in interface org.apache.accumulo.core.security.AuthorizationContainer
Checks whether this object contains the given authorization.
contains(byte[]) - Method in class org.apache.accumulo.core.security.Authorizations
Checks whether this object contains the given authorization.
contains(ByteSequence) - Method in class org.apache.accumulo.core.security.Authorizations
Checks whether this object contains the given authorization.
contains(String) - Method in class org.apache.accumulo.core.security.Authorizations
Checks whether this object contains the given authorization.
contains(KT) - Method in class org.apache.accumulo.core.util.MapCounter
 
containsCommand(String) - Method in class org.apache.accumulo.core.util.shell.Token
 
containsKey(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
containsValue(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
continueMultiScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
continueMultiScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
continueMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
continueMultiScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
continueScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
continueScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
continueScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
continueScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.AuthConverter
 
convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.MemoryConverter
 
convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.PasswordConverter
 
convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.TimeConverter
 
convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.VisibilityConverter
 
convert(String) - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC.PasswordConverter
 
convert(String) - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC.TokenConverter
 
convertClientConfig(AccumuloConfiguration, Configuration) - Static method in class org.apache.accumulo.core.client.impl.ServerConfigurationUtil
 
copy(byte[]) - Method in class org.apache.accumulo.core.data.Value
 
COPYONWRITE_ARRAYLIST - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for CopyOnWriteArrayList
COPYONWRITE_ARRAYSET - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for CopyOnWriteArraySet
copyPartialKey(Key, PartialKey) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Creates a copy of key, copying only the parts of the key specified in part.
CORE_PACKAGE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
count - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
CountingIterator - Class in org.apache.accumulo.core.iterators.system
 
CountingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.system.CountingIterator
 
cq - Variable in class org.apache.accumulo.core.data.thrift.TCondition
 
create(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Create an empty namespace with no initial configuration.
create(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Create a table with no special configuration
create(String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
create(String, boolean, TimeType) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
create(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
create(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Create a table with no special configuration
create(String, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
create(String, boolean, TimeType) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
create(HostAndPort, long) - Static method in class org.apache.accumulo.core.util.TTimeoutTransport
 
create(SocketAddress, long) - Static method in class org.apache.accumulo.core.util.TTimeoutTransport
 
create(T, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
Create a Volume with the given FileSystem that writes to the default path
create(T, String) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
create(String, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
create(Path, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
 
createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
Deprecated.
createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
Deprecated.
createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.Connector
Factory method to create a BatchScanner connected to Accumulo.
createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
createBatchScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
Factory method to create a BatchWriter connected to Accumulo.
createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
Deprecated.
createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
Deprecated.
createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
createClient(TServiceClientFactory<T>, TTransport) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
createClientTransport(HostAndPort, int, SslConnectionParams) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
Factory method to create a ConditionalWriter connected to Accumulo.
createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
CreateEmpty - Class in org.apache.accumulo.core.file.rfile
Create an empty RFile for use in recovering from data loss where Accumulo still refers internally to a path.
CreateEmpty() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty
 
CreateEmpty.IsSupportedCompressionAlgorithm - Class in org.apache.accumulo.core.file.rfile
 
CreateEmpty.IsSupportedCompressionAlgorithm() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty.IsSupportedCompressionAlgorithm
 
CreateEmpty.NamedLikeRFile - Class in org.apache.accumulo.core.file.rfile
 
CreateEmpty.NamedLikeRFile() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty.NamedLikeRFile
 
createEntry(Configuration, String, char[]) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
Create a CredentialEntry using the configured Providers.
createEntryInProvider(Object, String, char[]) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
Create a CredentialEntry with the give name and credential in the credentialProvider.
createFilter(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
createHeap(int) - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
 
createInstanceFromPropertyName(AccumuloConfiguration, Property, Class<T>, T) - Static method in enum org.apache.accumulo.core.conf.Property
 
createLocalUser(String, PasswordToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Create a user
createLocalUser(String, PasswordToken) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
createLocalUser(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
createLocalUser(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
createMetadataScanner(Instance, Credentials, String, Range) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Create an IsolatedScanner over the given table, fetching the columns necessary to determine when a table has transitioned to online or offline.
createMetaStore(String) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
createMetaStore(String) - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
createMetaStore(String) - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
Factory method to create a Multi-Table BatchWriter connected to Accumulo.
createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
Deprecated.
createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
Deprecated.
createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
createNamespace(String, String) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
CreateNamespaceCommand - Class in org.apache.accumulo.core.util.shell.commands
 
CreateNamespaceCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CreateNamespaceCommand
 
createParamsObjectFromAccumuloConfiguration(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloRowInputFormat
 
createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.Connector
Factory method to create a Scanner connected to Accumulo.
createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
createTable(String, String, boolean, TimeType) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
CreateTableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
CreateTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CreateTableCommand
 
createTableInstanceFromPropertyName(AccumuloConfiguration, Property, Class<T>, T) - Static method in enum org.apache.accumulo.core.conf.Property
 
CreateToken - Class in org.apache.accumulo.core.util
 
CreateToken() - Constructor for class org.apache.accumulo.core.util.CreateToken
 
createTransport(HostAndPort, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ThriftUtil
create a transport that is not pooled
createUser(String, byte[], Authorizations) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Deprecated.
since 1.5.0; use SecurityOperations.createLocalUser(String, PasswordToken) or the user management functions of your configured authenticator instead.
createUser(String, byte[], Authorizations) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
Deprecated.
CreateUserCommand - Class in org.apache.accumulo.core.util.shell.commands
 
CreateUserCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.CreateUserCommand
 
CREDENTIAL_PROVIDER_PATH - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
CREDENTIAL_PROVIDERS_PROPERTY - Static variable in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
CredentialProviderFactoryShim - Class in org.apache.accumulo.core.conf
Shim around Hadoop: tries to use the CredentialProviderFactory provided by hadoop-common, falling back to a copy inside accumulo-core.
CredentialProviderFactoryShim() - Constructor for class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
CredentialProviderToken - Class in org.apache.accumulo.core.client.security.tokens
An AuthenticationToken backed by a Hadoop CredentialProvider.
CredentialProviderToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
CredentialProviderToken(String, String) - Constructor for class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
credentials - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
Credentials - Class in org.apache.accumulo.core.security
A wrapper for internal use.
Credentials(String, AuthenticationToken) - Constructor for class org.apache.accumulo.core.security.Credentials
Creates a new credentials object.
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
CryptoModule - Interface in org.apache.accumulo.core.security.crypto
Classes that obey this interface may be used to provide encrypting and decrypting streams to the rest of Accumulo.
CryptoModuleFactory - Class in org.apache.accumulo.core.security.crypto
This factory module exists to assist other classes in loading crypto modules.
CryptoModuleFactory() - Constructor for class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
 
CryptoModuleParameters - Class in org.apache.accumulo.core.security.crypto
This class defines several parameters needed by by a module providing cryptographic stream support in Accumulo.
CryptoModuleParameters() - Constructor for class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
 
CT - Static variable in class org.apache.accumulo.core.client.impl.Translators
 
current - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
currentDocID - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
currentK - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
The Key that should be returned to the client
currentKey - Variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
 
currentKey - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
The Key that is used to determine progress in the current InputSplit.
currentLog - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
currentPartition - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
currentV - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
The Value that should be return to the client
cv - Variable in class org.apache.accumulo.core.data.thrift.TCondition
 
cve - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
CVST - Static variable in class org.apache.accumulo.core.client.impl.Translators
 

D

Daemon - Class in org.apache.accumulo.core.util
 
Daemon() - Constructor for class org.apache.accumulo.core.util.Daemon
 
Daemon(Runnable) - Constructor for class org.apache.accumulo.core.util.Daemon
 
Daemon(String) - Constructor for class org.apache.accumulo.core.util.Daemon
 
Daemon(ThreadGroup, Runnable) - Constructor for class org.apache.accumulo.core.util.Daemon
 
Daemon(ThreadGroup, String) - Constructor for class org.apache.accumulo.core.util.Daemon
 
Daemon(Runnable, String) - Constructor for class org.apache.accumulo.core.util.Daemon
 
Daemon(ThreadGroup, Runnable, String) - Constructor for class org.apache.accumulo.core.util.Daemon
 
Daemon(ThreadGroup, Runnable, String, long) - Constructor for class org.apache.accumulo.core.util.Daemon
 
data - Variable in class org.apache.accumulo.core.data.ArrayByteSequence
 
data - Variable in class org.apache.accumulo.core.data.ComparableBytes
 
data - Variable in class org.apache.accumulo.core.data.thrift.TMutation
 
dataCacheHits - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
dataCacheRequest - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
DataFileValue - Class in org.apache.accumulo.core.metadata.schema
 
DataFileValue(long, long, long) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
 
DataFileValue(long, long) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
 
DataFileValue(byte[]) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
 
DATE_FORMAT - Static variable in class org.apache.accumulo.core.trace.TraceFormatter
 
DATE_FORMAT - Static variable in class org.apache.accumulo.core.util.format.DateStringFormatter
 
DateLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for date objects.
DateLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.DateLexicoder
 
DateStringFormatter - Class in org.apache.accumulo.core.util.format
 
DateStringFormatter() - Constructor for class org.apache.accumulo.core.util.format.DateStringFormatter
 
DeadServer - Class in org.apache.accumulo.core.master.thrift
 
DeadServer() - Constructor for class org.apache.accumulo.core.master.thrift.DeadServer
 
DeadServer(String, long, String) - Constructor for class org.apache.accumulo.core.master.thrift.DeadServer
 
DeadServer(DeadServer) - Constructor for class org.apache.accumulo.core.master.thrift.DeadServer
Performs a deep copy on other.
DeadServer._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
deadTabletServers - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
debug - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
DebugCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DebugCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DebugCommand
 
DebugIterator - Class in org.apache.accumulo.core.iterators
 
DebugIterator() - Constructor for class org.apache.accumulo.core.iterators.DebugIterator
 
DebugIterator(String, SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.DebugIterator
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.DateLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.ListLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.LongLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.PairLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.ReverseLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.StringLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.TextLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
decode(byte[], int) - Static method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
 
decode(byte[]) - Method in interface org.apache.accumulo.core.iterators.TypedValueCombiner.Encoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
 
decodeBase64(byte[]) - Static method in class org.apache.accumulo.core.util.Base64
Decode, presuming bytes are base64.
decodeBase64(String) - Static method in class org.apache.accumulo.core.util.Base64
Decode, presuming String is base64.
decodeBase64FileName(String) - Static method in class org.apache.accumulo.core.util.Encoding
 
decodeBooleans(String) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
decodeColumnFamilies(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
decodeColumnFamily(Key, Value) - Static method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
Decode whole row/cf out of value.
decodeColumnFamily(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
decodeColumns(String) - Static method in class org.apache.accumulo.core.iterators.conf.ColumnSet
 
decodeColumns(String, String) - Static method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
Deprecated.
 
decodeColumns(String) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
decodeIteratorSettings(byte[]) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
decodePrevEndRow(Value) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
decodeRow(Key, Value) - Static method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
decompress(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.CompressedIterators
 
decompress(List<TKeyValue>) - Static method in class org.apache.accumulo.core.data.Key
Use this to decompress a list of keys received from thrift.
decrement(KT, long) - Method in class org.apache.accumulo.core.util.MapCounter
 
decryptSecretKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.CachingHDFSSecretKeyEncryptionStrategy
 
decryptSecretKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.NonCachingSecretKeyEncryptionStrategy
 
decryptSecretKey(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.SecretKeyEncryptionStrategy
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
deepCopy() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
deepCopy() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
deepCopy() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
deepCopy() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
deepCopy() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
deepCopy() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
deepCopy() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Combiner
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DevNull
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Filter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
deepCopy(IteratorEnvironment) - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Creates a deep copy of this iterator as though seek had not yet been called.
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.CountingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.DeletingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.MultiIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.StatsIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
Implement deepCopy.
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
deepCopy() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
deepCopy() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
DEFAULT_CACHE_TIME - Static variable in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
DEFAULT_CACHE_TIME_UNIT - Static variable in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
DEFAULT_DOC_COLF - Static variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
DEFAULT_INDEX_COLF - Static variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
DEFAULT_NAMESPACE - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
 
DEFAULT_NAMESPACE_ID - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
 
DEFAULT_TABLET_LOCATION - Static variable in class org.apache.accumulo.core.Constants
Initial tablet directory name for the default tablet in all tables
DEFAULT_VISIBILITY_CACHE_SIZE - Static variable in class org.apache.accumulo.core.Constants
 
DefaultConfiguration - Class in org.apache.accumulo.core.conf
 
DefaultConfiguration() - Constructor for class org.apache.accumulo.core.conf.DefaultConfiguration
 
DefaultCryptoModule - Class in org.apache.accumulo.core.security.crypto
This class implements the CryptoModule interface, defining how calling applications can receive encrypted input and output streams.
DefaultCryptoModule() - Constructor for class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
 
DefaultCryptoModuleUtils - Class in org.apache.accumulo.core.security.crypto
 
DefaultCryptoModuleUtils() - Constructor for class org.apache.accumulo.core.security.crypto.DefaultCryptoModuleUtils
 
DefaultFormatter - Class in org.apache.accumulo.core.util.format
 
DefaultFormatter() - Constructor for class org.apache.accumulo.core.util.format.DefaultFormatter
 
DefaultKeySizeConstraint - Class in org.apache.accumulo.core.constraints
A constraints that limits the size of keys to 1mb.
DefaultKeySizeConstraint() - Constructor for class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
 
defaultNamespace() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Returns the name of the default namespace
defaultNamespace() - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
DefaultScanInterpreter - Class in org.apache.accumulo.core.util.interpret
 
DefaultScanInterpreter() - Constructor for class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
 
defaultVisibility - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
delete(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Delete an empty namespace
delete(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Delete a table
delete() - Method in interface org.apache.accumulo.core.client.BatchDeleter
Deletes the ranges specified by BatchDeleter.setRanges(java.util.Collection).
delete(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
delete(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Delete a table
delete() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchDeleter
 
delete() - Method in class org.apache.accumulo.core.client.mock.MockBatchDeleter
 
DELETE_ROW_VALUE - Static variable in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
DeleteCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteCommand
 
deleted - Variable in class org.apache.accumulo.core.data.Key
 
deleted - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
DeleteIterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteIterCommand
 
DeleteManyCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteManyCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteManyCommand
 
DeleteNamespaceCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteNamespaceCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteNamespaceCommand
 
DeleterFormatter - Class in org.apache.accumulo.core.util.format
 
DeleterFormatter(BatchWriter, Iterable<Map.Entry<Key, Value>>, boolean, Shell, boolean) - Constructor for class org.apache.accumulo.core.util.format.DeleterFormatter
 
deleteRows(String, Text, Text) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Delete rows between (start, end]
deleteRows(String, Text, Text) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
DeleteRowsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteRowsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteRowsCommand
 
DeleteScanIterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteScanIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteScanIterCommand
 
DeleteShellIterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteShellIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteShellIterCommand
 
DeleteTableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteTableCommand
 
DeleteUserCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DeleteUserCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DeleteUserCommand
 
DeletingIterator - Class in org.apache.accumulo.core.iterators.system
 
DeletingIterator(DeletingIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.system.DeletingIterator
 
DeletingIterator() - Constructor for class org.apache.accumulo.core.iterators.system.DeletingIterator
 
DeletingIterator(SortedKeyValueIterator<Key, Value>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.DeletingIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.Combiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.Filter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.LongCombiner
 
describeOptions() - Method in interface org.apache.accumulo.core.iterators.OptionDescriber
Gets an iterator options object that contains information needed to configure this iterator.
describeOptions() - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.MaxCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.MinCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ReqVisFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.SummingCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
description - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
description - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.AboutCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.AddAuthsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.AddSplitsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.AuthenticateCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ClasspathCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ClearCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.CloneTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.CompactCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ConfigCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ConstraintCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.CreateNamespaceCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.CreateTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.CreateUserCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DebugCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteManyCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteNamespaceCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteRowsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteScanIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteShellIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DropUserCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.DUCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.EGrepCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ExecfileCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ExitCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ExportTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.FateCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.FlushCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.FormatterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.GetAuthsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.GetGroupsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.GetSplitsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.GrantCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.GrepCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.HelpCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.HiddenCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.HistoryCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ImportDirectoryCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ImportTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.InsertCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.InterpreterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ListCompactionsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ListIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ListScansCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ListShellIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.MaxRowCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.MergeCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.NamespacePermissionsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.NamespacesCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.NoTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.OfflineCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.OnlineCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.PasswdCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.PingCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.RenameNamespaceCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.RenameTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.RevokeCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.SetAuthsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.SetGroupsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.SetIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.SetScanIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.SetShellIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.SleepCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.SystemPermissionsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.TableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.TablePermissionsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.TablesCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.TraceCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.UserCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.UserPermissionsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.UsersCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.commands.WhoAmICommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
deserialize(String) - Static method in class org.apache.accumulo.core.client.ClientConfiguration
 
deserialize(Class<T>, byte[]) - Static method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
A convenience method to create tokens from serialized bytes, created by AuthenticationToken.AuthenticationTokenSerializer.serialize(AuthenticationToken)
deserialize(String, byte[]) - Static method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
An alternate version of AuthenticationToken.AuthenticationTokenSerializer.deserialize(Class, byte[]) that accepts a token class name rather than a token class.
deserialize(String) - Static method in class org.apache.accumulo.core.security.Credentials
Converts the serialized form to an instance of Credentials.
deserializeFetchedColumns(Collection<String>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
 
deserializeFetchedColumns(Collection<String>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
destroy() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
destroy() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
destroy() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
DevNull - Class in org.apache.accumulo.core.iterators
An iterator that is useful testing...
DevNull() - Constructor for class org.apache.accumulo.core.iterators.DevNull
 
DIRECTORY_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds the location of the tablet in the DFS file system
disable - Variable in class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
disableIsolation() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
disableIsolation() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
disableIsolation() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
disableIsolation() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
disableIsolation() - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
disableIsolation() - Method in interface org.apache.accumulo.core.client.Scanner
Disables row isolation.
disableUnflaggedTableOptions() - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
DiscardCloseOutputStream - Class in org.apache.accumulo.core.security.crypto
 
DiscardCloseOutputStream(OutputStream) - Constructor for class org.apache.accumulo.core.security.crypto.DiscardCloseOutputStream
 
DiskUsage - Class in org.apache.accumulo.core.client.admin
 
DiskUsage(SortedSet<String>, Long) - Constructor for class org.apache.accumulo.core.client.admin.DiskUsage
 
DistributedCacheHelper - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
 
DistributedCacheHelper() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
 
DistributedTrace - Class in org.apache.accumulo.core.trace
 
DistributedTrace() - Constructor for class org.apache.accumulo.core.trace.DistributedTrace
 
docSource - Variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
doLookup(Instance, Credentials, String, Map<KeyExtent, List<Range>>, Map<KeyExtent, List<Range>>, Map<KeyExtent, List<Range>>, TabletServerBatchReaderIterator.ResultReceiver, List<Column>, ScannerOptions, Authorizations, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator
 
doTableOp(Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.CompactCommand
 
doTableOp(Shell, String, boolean) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteNamespaceCommand
 
doTableOp(Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteTableCommand
 
doTableOp(Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.FlushCommand
 
doTableOp(Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.GrantCommand
 
doTableOp(Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.OfflineCommand
 
doTableOp(Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.OnlineCommand
 
doTableOp(Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.RevokeCommand
 
doTableOp(Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
DoubleLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for preserving the native Java sort order of Double values.
DoubleLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
 
dropLocalUser(String) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Delete a user
dropLocalUser(String) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
dropLocalUser(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
dropLocalUser(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
dropLocalUser(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
dropLocalUser(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
droppingOldTimestamp(long) - Method in class org.apache.accumulo.core.data.Mutation
 
DropTableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DropTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DropTableCommand
 
dropUser(String) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Deprecated.
since 1.5.0; use SecurityOperations.dropUser(String) or the user management functions of your configured authenticator instead.
dropUser(String) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
Deprecated.
DropUserCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DropUserCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DropUserCommand
 
DUCommand - Class in org.apache.accumulo.core.util.shell.commands
 
DUCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.DUCommand
 
dumps - Variable in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
 
duplicateReads() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
Duration - Class in org.apache.accumulo.core.util
 
Duration() - Constructor for class org.apache.accumulo.core.util.Duration
 
DynamicBloomFilter - Class in org.apache.accumulo.core.bloomfilter
Implements a dynamic Bloom filter, as defined in the INFOCOM 2006 paper.
DynamicBloomFilter() - Constructor for class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
Zero-args constructor for the serialization.
DynamicBloomFilter(int, int, int, int) - Constructor for class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
Constructor.

E

EGrepCommand - Class in org.apache.accumulo.core.util.shell.commands
 
EGrepCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.EGrepCommand
 
elapsed - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
EMPTY - Static variable in class org.apache.accumulo.core.security.Authorizations
An empty set of authorizations.
EMPTY - Static variable in class org.apache.accumulo.core.security.ColumnVisibility.Node
An empty list of nodes.
EMPTY_CF_SET - Static variable in class org.apache.accumulo.core.util.LocalityGroupUtil
 
enable(Instance, ZooReader, String, String) - Static method in class org.apache.accumulo.core.trace.DistributedTrace
 
enable - Variable in class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
enableIsolation() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
enableIsolation() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
enableIsolation() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
enableIsolation() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
enableIsolation() - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
enableIsolation() - Method in interface org.apache.accumulo.core.client.Scanner
Enables row isolation.
encode(BigInteger) - Method in class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
 
encode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
 
encode(Date) - Method in class org.apache.accumulo.core.client.lexicoder.DateLexicoder
 
encode(Double) - Method in class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
 
encode(Integer) - Method in class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
 
encode(List<LT>) - Method in class org.apache.accumulo.core.client.lexicoder.ListLexicoder
 
encode(Long) - Method in class org.apache.accumulo.core.client.lexicoder.LongLexicoder
 
encode(ComparablePair<A, B>) - Method in class org.apache.accumulo.core.client.lexicoder.PairLexicoder
 
encode(T) - Method in class org.apache.accumulo.core.client.lexicoder.ReverseLexicoder
 
encode(String) - Method in class org.apache.accumulo.core.client.lexicoder.StringLexicoder
 
encode(Text) - Method in class org.apache.accumulo.core.client.lexicoder.TextLexicoder
 
encode(Integer) - Method in class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
 
encode(Long) - Method in class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
 
encode(UUID) - Method in class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
 
encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
 
encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
 
encode(V) - Method in interface org.apache.accumulo.core.iterators.TypedValueCombiner.Encoder
 
encode(BigDecimal) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
 
encode(List<V>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
encode(List<Long>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
 
encode() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
encodeAsBase64FileName(Text) - Static method in class org.apache.accumulo.core.util.Encoding
 
encodeAsString() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
encodeAsValue() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
encodeBase64(byte[]) - Static method in class org.apache.accumulo.core.util.Base64
Serialize to Base64 byte array, non-chunked.
encodeBase64String(byte[]) - Static method in class org.apache.accumulo.core.util.Base64
Serialize to Base64 as a String, non-chunked.
encodeBase64URLSafeString(byte[]) - Static method in class org.apache.accumulo.core.util.Base64
Serialize to Base64 as a String using the URLSafe alphabet, non-chunked.
encodeBooleans(boolean[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
encodeColumnFamilies(Set<Text>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
encodeColumnFamily(List<Key>, List<Value>) - Static method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
Encode row/cf.
encodeColumnFamily(ByteSequence) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
encodeColumns(Text, Text) - Static method in class org.apache.accumulo.core.iterators.conf.ColumnSet
 
encodeColumns() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
Deprecated.
 
encodeColumns(Text, Text) - Static method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
Deprecated.
 
encodeColumns(Text[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
encodeIteratorSettings(IteratorConfig) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
encodeIteratorSettings(List<IteratorSetting>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
encodePrevEndRow(Text) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
Encoder<T> - Interface in org.apache.accumulo.core.client.lexicoder
An encoder represents a typed object that can be encoded/decoded to/from a byte array.
encodeRow(List<Key>, List<Value>) - Static method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
ENCODING - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
Encoding - Class in org.apache.accumulo.core.util
 
Encoding() - Constructor for class org.apache.accumulo.core.util.Encoding
 
ENCODING_DEFAULT - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
encryptSecretKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.CachingHDFSSecretKeyEncryptionStrategy
 
encryptSecretKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.NonCachingSecretKeyEncryptionStrategy
 
encryptSecretKey(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.SecretKeyEncryptionStrategy
 
END - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
END_BOUND - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
END_INCL - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
END_INCLUSIVE - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
END_ROW_OPT - Static variable in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
endRow - Variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
endRow - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
endRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
endRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
endRowOpt() - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
engine - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
entries - Variable in class org.apache.accumulo.core.data.thrift.TMutation
 
entriesRead - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
entriesWritten - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
entrySet() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
enumToConfKey(Class<?>, Enum<?>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Provides a configuration key for a given feature enum, prefixed by the implementingClass
enumToConfKey(Enum<?>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Provides a configuration key for a given feature enum.
enumToConfKey(Class<?>, Enum<?>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
equals(Object) - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
equals(Object) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
equals(ClientService.authenticate_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
equals(ClientService.authenticate_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
equals(ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
equals(ClientService.authenticateUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
equals(ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
equals(ClientService.bulkImportFiles_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
equals(ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
equals(ClientService.changeAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
equals(ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
equals(ClientService.changeLocalUserPassword_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
equals(ClientService.checkClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
equals(ClientService.checkClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
equals(ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
equals(ClientService.checkNamespaceClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
equals(ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
equals(ClientService.checkTableClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
equals(ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
equals(ClientService.createLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
equals(ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
equals(ClientService.dropLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
equals(ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
equals(ClientService.getConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
equals(ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
equals(ClientService.getDiskUsage_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
equals(ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
equals(ClientService.getInstanceId_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
equals(ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
equals(ClientService.getNamespaceConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
equals(ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
equals(ClientService.getRootTabletLocation_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
equals(ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
equals(ClientService.getTableConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
equals(ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
equals(ClientService.getUserAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
equals(ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
equals(ClientService.getZooKeepers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
equals(ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
equals(ClientService.grantNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
equals(ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
equals(ClientService.grantSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
equals(ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
equals(ClientService.grantTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
equals(ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
equals(ClientService.hasNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
equals(ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
equals(ClientService.hasSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
equals(ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
equals(ClientService.hasTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
equals(ClientService.isActive_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
equals(ClientService.isActive_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
equals(ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
equals(ClientService.listLocalUsers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
equals(ClientService.ping_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
equals(ClientService.ping_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
equals(ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
equals(ClientService.revokeNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
equals(ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
equals(ClientService.revokeSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
equals(ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
equals(ClientService.revokeTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
equals(TDiskUsage) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
equals(Object) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
equals(ThriftSecurityException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
equals(Object) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
equals(ThriftTableOperationException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
equals(ThriftTest.fails_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
equals(ThriftTest.fails_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
equals(ThriftTest.success_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
equals(ThriftTest.success_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
equals(ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
equals(ThriftTest.throwsError_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
 
equals(Object) - Method in class org.apache.accumulo.core.client.IteratorSetting
 
equals(Object) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
 
equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
equals(Object) - Method in class org.apache.accumulo.core.data.ByteSequence
 
equals(Object) - Method in class org.apache.accumulo.core.data.Column
 
equals(Column) - Method in class org.apache.accumulo.core.data.Column
 
equals(Object) - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
equals(Object) - Method in class org.apache.accumulo.core.data.Condition
 
equals(Object) - Method in class org.apache.accumulo.core.data.ConditionalMutation
 
equals(Object) - Method in class org.apache.accumulo.core.data.Key
 
equals(Key, PartialKey) - Method in class org.apache.accumulo.core.data.Key
Compare part of a key.
equals(Object) - Method in class org.apache.accumulo.core.data.KeyExtent
 
equals(Object) - Method in class org.apache.accumulo.core.data.Mutation
 
equals(Mutation) - Method in class org.apache.accumulo.core.data.Mutation
Checks if this mutation equals another.
equals(Object) - Method in class org.apache.accumulo.core.data.Range
 
equals(Range) - Method in class org.apache.accumulo.core.data.Range
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
equals(InitialMultiScan) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
equals(InitialScan) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
equals(IterInfo) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
equals(MapFileInfo) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
equals(MultiScanResult) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
equals(ScanResult) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
equals(TCMResult) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
equals(TColumn) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
equals(TCondition) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
equals(TConditionalMutation) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
equals(TConditionalSession) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
equals(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
equals(TKey) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
equals(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
equals(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
equals(TMutation) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
equals(TRange) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
equals(Object) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
equals(UpdateErrors) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
equals(Object) - Method in class org.apache.accumulo.core.data.Value
 
equals(Object) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
 
equals(Object) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
equals(Object) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
equals(Object) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
equals(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
equals(Object) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
equals(GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
equals(Object) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
equals(GCMonitorService.getStatus_result) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
equals(Object) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
equals(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
equals(Object) - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColFamHashKey
 
equals(ColumnUtil.ColFamHashKey) - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColFamHashKey
 
equals(Object) - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColHashKey
 
equals(ColumnUtil.ColHashKey) - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColHashKey
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
equals(Compacting) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
equals(DeadServer) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
equals(FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
equals(FateService.beginFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
equals(FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
equals(FateService.executeFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
equals(FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
equals(FateService.finishFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
equals(FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
equals(FateService.waitForFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
equals(MasterClientService.getMasterStats_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
equals(MasterClientService.getMasterStats_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
equals(MasterClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
equals(MasterClientService.initiateFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
equals(MasterClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
equals(MasterClientService.removeNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
equals(MasterClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
equals(MasterClientService.removeSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
equals(MasterClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
equals(MasterClientService.removeTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
equals(MasterClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
equals(MasterClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
equals(MasterClientService.setMasterGoalState_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
equals(MasterClientService.setMasterGoalState_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
equals(MasterClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
equals(MasterClientService.setNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
equals(MasterClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
equals(MasterClientService.setSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
equals(MasterClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
equals(MasterClientService.setTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
equals(MasterClientService.shutdown_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
equals(MasterClientService.shutdown_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
equals(MasterClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
equals(MasterClientService.shutdownTabletServer_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
equals(MasterClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
equals(MasterClientService.waitForFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
equals(MasterMonitorInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
equals(Object) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
equals(RecoveryException) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
equals(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
equals(TableInfo) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
equals(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
equals(TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
equals(Object) - Method in class org.apache.accumulo.core.security.Authorizations
 
equals(Object) - Method in class org.apache.accumulo.core.security.ColumnVisibility
equals(ColumnVisibility) - Method in class org.apache.accumulo.core.security.ColumnVisibility
Compares two ColumnVisibilities for string equivalence, not as a meaningful comparison of terms and conditions.
equals(Object) - Method in class org.apache.accumulo.core.security.Credentials
 
equals(Object) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
equals(TCredentials) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
equals(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
equals(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
equals(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
equals(ConstraintViolationException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
equals(IteratorConfig) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
equals(NoSuchScanIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
equals(NotServingTabletException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
equals(TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
equals(TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
equals(TabletClientService.bulkImport_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
equals(TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
equals(TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
equals(TabletClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
equals(TabletClientService.closeMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
equals(TabletClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
equals(TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
equals(TabletClientService.closeUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
equals(TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
equals(TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
equals(TabletClientService.conditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
equals(TabletClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
equals(TabletClientService.continueMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
equals(TabletClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
equals(TabletClientService.continueScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
equals(TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
equals(TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
equals(TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
equals(TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
equals(TabletClientService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
equals(TabletClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
equals(TabletClientService.getActiveScans_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
equals(TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
equals(TabletClientService.getHistoricalStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
equals(TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
equals(TabletClientService.getTabletServerStatus_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
equals(TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
equals(TabletClientService.getTabletStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
equals(TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
equals(TabletClientService.halt_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
equals(TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
equals(TabletClientService.invalidateConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
equals(TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
equals(TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
equals(TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
equals(TabletClientService.splitTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
equals(TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
equals(TabletClientService.startConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
equals(TabletClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
equals(TabletClientService.startMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
equals(TabletClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
equals(TabletClientService.startScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
equals(TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
equals(TabletClientService.startUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
equals(TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
equals(TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
equals(TabletClientService.update_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
equals(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
equals(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
equals(TooManyFilesException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
equals(Object) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
equals(Text, Text) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
equals(Object) - Method in class org.apache.accumulo.core.util.Pair
 
equals(Object) - Method in class org.apache.accumulo.core.util.ServerServices
 
equals(Object) - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
equals(Object) - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
 
equals(Object) - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
errorDir - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
errors - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
escape(byte[]) - Static method in class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
Escapes 0x00 with 0x01 0x01 and 0x01 with 0x01 0x02
escape(byte[], boolean) - Static method in class org.apache.accumulo.core.security.VisibilityEvaluator
Properly escapes an authorization string.
estimateBase(Class<?>, boolean) - Static method in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Estimate the static space taken up by the fields of a class.
estimatedMemoryUsed() - Method in class org.apache.accumulo.core.data.Mutation
 
estimatedSize - Variable in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
evaluate(ColumnVisibility) - Method in class org.apache.accumulo.core.security.VisibilityEvaluator
Evaluates the given column visibility against the authorizations provided to this evaluator.
evict() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
evictBlock(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
evicted() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
evictedPerEviction() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
ex - Variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
exact(Text) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row Returns the same Range as new Range(row)
exact(Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row and column family
exact(Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, and column qualifier
exact(Text, Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, column qualifier, and visibility
exact(Text, Text, Text, Text, long) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, column qualifier, visibility, and timestamp
exact(CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row
exact(CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row and column family
exact(CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, and column qualifier
exact(CharSequence, CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, column qualifier, and visibility
exact(CharSequence, CharSequence, CharSequence, CharSequence, long) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, column qualifier, visibility, and timestamp
execCommand - Variable in class org.apache.accumulo.core.util.shell.Shell
 
execCommand(String, boolean, boolean) - Method in class org.apache.accumulo.core.util.shell.Shell
 
execFile - Variable in class org.apache.accumulo.core.util.shell.Shell
 
ExecfileCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ExecfileCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ExecfileCommand
 
execute(T) - Method in interface org.apache.accumulo.core.client.impl.ClientExec
 
execute(C) - Method in interface org.apache.accumulo.core.client.impl.ClientExecReturn
 
execute(Instance, ClientExecReturn<T, MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
execute(Instance, ClientExec<MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
execute(Instance, ClientExecReturn<T, ClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
execute(Instance, ClientExec<ClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.AboutCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.AddAuthsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.AddSplitsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.AuthenticateCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ClasspathCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ClearCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.CloneTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.CompactCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ConfigCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ConstraintCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.CreateNamespaceCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.CreateTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.CreateUserCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DebugCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteManyCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteNamespaceCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteRowsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteScanIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteShellIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DropUserCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.DUCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ExecfileCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ExitCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ExportTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.FateCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.FlushCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.GetAuthsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.GetGroupsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.GetSplitsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.GrantCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.GrepCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.HelpCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.HiddenCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.HistoryCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ImportDirectoryCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ImportTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.InsertCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ListCompactionsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ListIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ListScansCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ListShellIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.MaxRowCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.MergeCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.NamespacePermissionsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.NamespacesCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.NoTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.OfflineCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.OnlineCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.PasswdCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.PingCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.RenameNamespaceCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.RenameTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.RevokeCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.SetAuthsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.SetGroupsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.SetIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.SetScanIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.SetShellIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ShellPluginConfigurationCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.SleepCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.SystemPermissionsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.TableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.TablePermissionsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.TablesCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.TraceCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.UserCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.UserPermissionsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.UsersCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.WhoAmICommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
execute(String, AccumuloConfiguration, ClientExec<TabletClientService.Client>) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
execute(String, AccumuloConfiguration, ClientExecReturn<T, TabletClientService.Client>) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient
 
executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.FateService.AsyncIface
 
executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Method in interface org.apache.accumulo.core.master.thrift.FateService.Iface
 
executeGeneric(Instance, ClientExec<MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
executeNamespace(Instance, ClientExec<MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
executeRaw(Instance, ClientExecReturn<T, ClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
executeRaw(Instance, ClientExec<ClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
executeTable(Instance, ClientExec<MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
exists(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
A method to check if a namespace exists in Accumulo.
exists(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
A method to check if a table exists in Accumulo.
exists(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
exists(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
 
exists(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
A method to check if a table exists in Accumulo.
exists(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
exit(int) - Method in class org.apache.accumulo.core.cli.Help
 
exitCode - Variable in class org.apache.accumulo.core.util.shell.Shell
 
ExitCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ExitCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ExitCommand
 
exitWithError(String, int) - Method in class org.apache.accumulo.core.cli.Help
 
expireAllObservers() - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
Expires all observers.
EXPORT_FILE - Static variable in class org.apache.accumulo.core.Constants
 
EXPORT_INFO_FILE - Static variable in class org.apache.accumulo.core.Constants
 
EXPORT_METADATA_FILE - Static variable in class org.apache.accumulo.core.Constants
 
EXPORT_TABLE_CONFIG_FILE - Static variable in class org.apache.accumulo.core.Constants
 
exportTable(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Exports a table.
exportTable(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
ExportTableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ExportTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ExportTableCommand
 
EXTENSION - Static variable in class org.apache.accumulo.core.file.rfile.RFile
 
ExtensionCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ExtensionCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
EXTENT - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
extent - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
extent - Variable in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
extent - Variable in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 

F

fail - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
failedExtents - Variable in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
fails(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient
 
fails(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncIface
 
fails() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
fails() - Method in interface org.apache.accumulo.core.client.impl.thrift.ThriftTest.Iface
 
failures - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
families(Collection<Column>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
FamilyIntersectingIterator - Class in org.apache.accumulo.core.iterators
Deprecated.
since 1.4, replaced by IndexedDocIterator
FamilyIntersectingIterator() - Constructor for class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
Deprecated.
 
FastFormat - Class in org.apache.accumulo.core.util
 
FastFormat() - Constructor for class org.apache.accumulo.core.util.FastFormat
 
fastHalt(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
fastHalt(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
fastHalt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
fastHalt(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
fastSkip(DataInput, Key, MutableByteSequence, Key, Key) - Static method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
FateCommand - Class in org.apache.accumulo.core.util.shell.commands
Manage FATE transactions
FateCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.FateCommand
 
FateOperation - Enum in org.apache.accumulo.core.master.thrift
 
FateService - Class in org.apache.accumulo.core.master.thrift
 
FateService() - Constructor for class org.apache.accumulo.core.master.thrift.FateService
 
FateService.AsyncClient - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient
 
FateService.AsyncClient.beginFateOperation_call - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncClient.beginFateOperation_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.beginFateOperation_call
 
FateService.AsyncClient.executeFateOperation_call - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncClient.executeFateOperation_call(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.executeFateOperation_call
 
FateService.AsyncClient.Factory - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.Factory
 
FateService.AsyncClient.finishFateOperation_call - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncClient.finishFateOperation_call(TInfo, TCredentials, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.finishFateOperation_call
 
FateService.AsyncClient.waitForFateOperation_call - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncClient.waitForFateOperation_call(TInfo, TCredentials, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.waitForFateOperation_call
 
FateService.AsyncIface - Interface in org.apache.accumulo.core.master.thrift
 
FateService.AsyncProcessor<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor
 
FateService.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor
 
FateService.AsyncProcessor.beginFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncProcessor.beginFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.beginFateOperation
 
FateService.AsyncProcessor.executeFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncProcessor.executeFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
 
FateService.AsyncProcessor.finishFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncProcessor.finishFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
 
FateService.AsyncProcessor.waitForFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.AsyncProcessor.waitForFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.waitForFateOperation
 
FateService.beginFateOperation_args - Class in org.apache.accumulo.core.master.thrift
 
FateService.beginFateOperation_args() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
FateService.beginFateOperation_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
FateService.beginFateOperation_args(FateService.beginFateOperation_args) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
Performs a deep copy on other.
FateService.beginFateOperation_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.beginFateOperation_result - Class in org.apache.accumulo.core.master.thrift
 
FateService.beginFateOperation_result() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
FateService.beginFateOperation_result(long, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
FateService.beginFateOperation_result(FateService.beginFateOperation_result) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
Performs a deep copy on other.
FateService.beginFateOperation_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.Client - Class in org.apache.accumulo.core.master.thrift
 
FateService.Client(TProtocol) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Client
 
FateService.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Client
 
FateService.Client.Factory - Class in org.apache.accumulo.core.master.thrift
 
FateService.Client.Factory() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Client.Factory
 
FateService.executeFateOperation_args - Class in org.apache.accumulo.core.master.thrift
 
FateService.executeFateOperation_args() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
FateService.executeFateOperation_args(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
FateService.executeFateOperation_args(FateService.executeFateOperation_args) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Performs a deep copy on other.
FateService.executeFateOperation_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.executeFateOperation_result - Class in org.apache.accumulo.core.master.thrift
 
FateService.executeFateOperation_result() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
FateService.executeFateOperation_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
FateService.executeFateOperation_result(FateService.executeFateOperation_result) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
Performs a deep copy on other.
FateService.executeFateOperation_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.finishFateOperation_args - Class in org.apache.accumulo.core.master.thrift
 
FateService.finishFateOperation_args() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
FateService.finishFateOperation_args(TInfo, TCredentials, long) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
FateService.finishFateOperation_args(FateService.finishFateOperation_args) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
Performs a deep copy on other.
FateService.finishFateOperation_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.finishFateOperation_result - Class in org.apache.accumulo.core.master.thrift
 
FateService.finishFateOperation_result() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
FateService.finishFateOperation_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
FateService.finishFateOperation_result(FateService.finishFateOperation_result) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
Performs a deep copy on other.
FateService.finishFateOperation_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.Iface - Interface in org.apache.accumulo.core.master.thrift
 
FateService.Processor<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.Processor(I) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor
 
FateService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor
 
FateService.Processor.beginFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.Processor.beginFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor.beginFateOperation
 
FateService.Processor.executeFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.Processor.executeFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor.executeFateOperation
 
FateService.Processor.finishFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.Processor.finishFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor.finishFateOperation
 
FateService.Processor.waitForFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
FateService.Processor.waitForFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor.waitForFateOperation
 
FateService.waitForFateOperation_args - Class in org.apache.accumulo.core.master.thrift
 
FateService.waitForFateOperation_args() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
FateService.waitForFateOperation_args(TInfo, TCredentials, long) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
FateService.waitForFateOperation_args(FateService.waitForFateOperation_args) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
Performs a deep copy on other.
FateService.waitForFateOperation_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.waitForFateOperation_result - Class in org.apache.accumulo.core.master.thrift
 
FateService.waitForFateOperation_result() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
FateService.waitForFateOperation_result(String, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
FateService.waitForFateOperation_result(FateService.waitForFateOperation_result) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
Performs a deep copy on other.
FateService.waitForFateOperation_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
fetch(ScannerBase) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
fetchColumn(Text, Text) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
fetchColumn(Column) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
fetchColumn(Text, Text) - Method in interface org.apache.accumulo.core.client.ScannerBase
Adds a column to the list of columns that will be fetched by this scanner.
fetchColumnFamily(Text) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Limit a scan to the specified column family.
fetchColumnFamily(Text) - Method in interface org.apache.accumulo.core.client.ScannerBase
Adds a column family to the list of columns that will be fetched by this scanner.
fetchColumns(JobConf, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Restricts the columns that will be mapped over for this job.
fetchColumns(Job, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Restricts the columns that will be mapped over for this job for the default input table.
fetchColumns(Collection<Pair<Text, Text>>) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Restricts the columns that will be mapped over for this job for the default input table.
fetchColumns(Class<?>, Configuration, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Restricts the columns that will be mapped over for the single input table on this job.
fetchColumns(Class<?>, Configuration, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
fetchColumns(CommandLine, ScannerBase, ScanInterpreter) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
fetchedColumns - Variable in class org.apache.accumulo.core.client.impl.ScannerOptions
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
fieldForId(int) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
fieldForId(int) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
fieldForId(int) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
fieldForId(int) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
file - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
filename - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
filenames - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
FileOperations - Class in org.apache.accumulo.core.file
 
FileOperations() - Constructor for class org.apache.accumulo.core.file.FileOperations
 
FileOutputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
 
FileOutputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
 
FileOutputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
FileOutputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
Deprecated.
 
FileOutputConfigurator.Opts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
Configuration keys for AccumuloConfiguration.
FileOutputConfigurator.Opts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
files - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
files - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
FileSKVIterator - Interface in org.apache.accumulo.core.file
 
FileSKVWriter - Interface in org.apache.accumulo.core.file
 
fillParamsObjectFromConfiguration(CryptoModuleParameters, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
 
fillParamsObjectFromStringMap(CryptoModuleParameters, Map<String, String>) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
 
Filter - Class in org.apache.accumulo.core.bloomfilter
Defines the general behavior of a filter.
Filter() - Constructor for class org.apache.accumulo.core.bloomfilter.Filter
 
Filter(int, int, int) - Constructor for class org.apache.accumulo.core.bloomfilter.Filter
Constructor.
Filter - Class in org.apache.accumulo.core.iterators
A SortedKeyValueIterator that filters entries from its source iterator.
Filter() - Constructor for class org.apache.accumulo.core.iterators.Filter
 
filter(Text, List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
filter(Text, List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
FilteredConstants - Class in org.apache.accumulo.core
 
FilteredConstants() - Constructor for class org.apache.accumulo.core.FilteredConstants
 
filterInvalidLabelsOnly(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
finalize() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
Warning: do not rely upon finalize to close this class.
finalize() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
Warning: do not rely upon finalize to close this class.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ConfigurationType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TableOperation
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCMStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateOperation
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterGoalState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletLoadState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionReason
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findChildren(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
findContainingExtent(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
FindMax - Class in org.apache.accumulo.core.client.admin
 
FindMax() - Constructor for class org.apache.accumulo.core.client.admin.FindMax
 
findMax(Scanner, Text, boolean, Text, boolean) - Static method in class org.apache.accumulo.core.client.admin.FindMax
 
findOverlapping(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
findOverlapping(KeyExtent, SortedMap<KeyExtent, ?>) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
findTop() - Method in class org.apache.accumulo.core.iterators.Filter
Iterates over the source until an acceptable key/value pair is found.
finished - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
finishFateOperation(TInfo, TCredentials, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient
 
finishFateOperation(TInfo, TCredentials, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.FateService.AsyncIface
 
finishFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
finishFateOperation(TInfo, TCredentials, long) - Method in interface org.apache.accumulo.core.master.thrift.FateService.Iface
 
FirstEntryInRowIterator - Class in org.apache.accumulo.core.iterators
 
FirstEntryInRowIterator() - Constructor for class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
FirstEntryInRowIterator(FirstEntryInRowIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
FIXED_LEN_ENCODER - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
FIXED_LONG_ARRAY_ENCODER - Static variable in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
FixedByteArrayOutputStream - Class in org.apache.accumulo.core.client.lexicoder.impl
Uses a fixed length array and will not grow in size dynamically like the ByteArrayOutputStream.
FixedByteArrayOutputStream(byte[]) - Constructor for class org.apache.accumulo.core.client.lexicoder.impl.FixedByteArrayOutputStream
 
flatten() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Generates a byte[] that represents a normalized, but logically equivalent, form of this evaluator's expression.
flush(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Deprecated.
flush(String, Text, Text, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Flush a table's data that is currently in memory.
flush() - Method in interface org.apache.accumulo.core.client.BatchWriter
Send any buffered mutations to Accumulo immediately.
flush() - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
 
flush() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
flush(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
flush(String, Text, Text, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Flush a table
flush() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
 
flush() - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
 
flush() - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
 
flush() - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
Send mutations for all tables to accumulo.
flush() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
 
flush() - Method in class org.apache.accumulo.core.security.crypto.BlockedOutputStream
 
flush() - Method in class org.apache.accumulo.core.security.crypto.NoFlushOutputStream
 
flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
FLUSH_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds flush IDs to enable waiting on a flush to complete
FlushCommand - Class in org.apache.accumulo.core.util.shell.commands
 
FlushCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.FlushCommand
 
flushID - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
flushTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
flushTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
flushTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
flushTablet(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
followingKey(PartialKey) - Method in class org.apache.accumulo.core.data.Key
Returns a key that will sort immediately after this key.
followingPrefix(Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Text that sorts just after all Texts beginning with a prefix
force - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
force() - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
forClient(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.SslConnectionParams
 
forConfig(AccumuloConfiguration, boolean) - Static method in class org.apache.accumulo.core.util.SslConnectionParams
 
format(long) - Static method in class org.apache.accumulo.core.util.Duration
 
format(long, String) - Static method in class org.apache.accumulo.core.util.Duration
 
format(long, String, String) - Static method in class org.apache.accumulo.core.util.Duration
 
formatDate(Date) - Static method in class org.apache.accumulo.core.trace.TraceFormatter
 
formatEntry(Map.Entry<Key, Value>, boolean) - Static method in class org.apache.accumulo.core.util.format.BinaryFormatter
 
formatEntry(Map.Entry<Key, Value>, boolean) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
formatEntry(Map.Entry<Key, Value>, DateFormat) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
Formatter - Interface in org.apache.accumulo.core.util.format
 
FormatterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
FormatterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.FormatterCommand
 
FormatterFactory - Class in org.apache.accumulo.core.util.format
 
forServer(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.SslConnectionParams
 
forTableId(Instance, Credentials, String) - Static method in class org.apache.accumulo.core.metadata.MetadataServicer
 
forTableName(Instance, Credentials, String) - Static method in class org.apache.accumulo.core.metadata.MetadataServicer
 
fromBytes(byte[]) - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
fromEntry(Map.Entry<K, V>) - Static method in class org.apache.accumulo.core.util.Pair
 
fromKeyValue(Key, Value) - Static method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
fromStrings(Collection<String>) - Static method in class org.apache.accumulo.core.util.ByteArraySet
 
fromStrings(String...) - Static method in class org.apache.accumulo.core.util.ByteArraySet
 
fromThrift(TCredentials) - Static method in class org.apache.accumulo.core.security.Credentials
Converts a given thrift object to our internal Credentials representation.
fs - Variable in class org.apache.accumulo.core.volume.VolumeImpl
 
fullScans - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
function - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 

G

GcCycleStats - Class in org.apache.accumulo.core.gc.thrift
 
GcCycleStats() - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
GcCycleStats(long, long, long, long, long, long) - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
GcCycleStats(GcCycleStats) - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
Performs a deep copy on other.
GcCycleStats._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService
 
GCMonitorService.AsyncClient - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient
 
GCMonitorService.AsyncClient.Factory - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.Factory
 
GCMonitorService.AsyncClient.getStatus_call - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncClient.getStatus_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
 
GCMonitorService.AsyncIface - Interface in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncProcessor<I extends GCMonitorService.AsyncIface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor
 
GCMonitorService.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor
 
GCMonitorService.AsyncProcessor.getStatus<I extends GCMonitorService.AsyncIface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncProcessor.getStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
GCMonitorService.Client - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Client(TProtocol) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
GCMonitorService.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
GCMonitorService.Client.Factory - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Client.Factory() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
 
GCMonitorService.getStatus_args - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.getStatus_args() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
GCMonitorService.getStatus_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
GCMonitorService.getStatus_args(GCMonitorService.getStatus_args) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
Performs a deep copy on other.
GCMonitorService.getStatus_args._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService.getStatus_result - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.getStatus_result() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
GCMonitorService.getStatus_result(GCStatus, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
GCMonitorService.getStatus_result(GCMonitorService.getStatus_result) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
Performs a deep copy on other.
GCMonitorService.getStatus_result._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService.Iface - Interface in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Processor<I extends GCMonitorService.Iface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Processor(I) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor
 
GCMonitorService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor
 
GCMonitorService.Processor.getStatus<I extends GCMonitorService.Iface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Processor.getStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
GCStatus - Class in org.apache.accumulo.core.gc.thrift
 
GCStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
 
GCStatus(GcCycleStats, GcCycleStats, GcCycleStats, GcCycleStats) - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
 
GCStatus(GCStatus) - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
Performs a deep copy on other.
GCStatus._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GENERATED_TABLET_DIRECTORY_PREFIX - Static variable in class org.apache.accumulo.core.Constants
 
generateInitialTableProperties(boolean) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
Generate the initial (default) properties for a table
generateNewRandomSessionKey(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.CryptoModule
Generates a random session key and sets it into the CryptoModuleParameters.getPlaintextKey() property.
generateNewRandomSessionKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
 
get(ClientConfiguration.ClientProperty) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Returns the value for prop, the default value if not present.
get(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
get(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
get(Property) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
get(Property) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
get(Property) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
get() - Method in class org.apache.accumulo.core.data.Value
 
get() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
Get a sorted List of all elements in this queue, in descending order.
get(KT) - Method in class org.apache.accumulo.core.util.MapCounter
 
get(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
getAccumuloConfiguration(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
This helper method provides an AccumuloConfiguration object constructed from the Accumulo defaults, and overridden with Accumulo properties that have been stored in the Job's configuration.
getAccumuloConfiguration(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
This helper method provides an AccumuloConfiguration object constructed from the Accumulo defaults, and overridden with Accumulo properties that have been stored in the Job's configuration.
getAccumuloConfiguration(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
This helper method provides an AccumuloConfiguration object constructed from the Accumulo defaults, and overridden with Accumulo properties that have been stored in the Job's configuration.
getAccumuloConfiguration(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getAccumuloProperty() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
 
getActiveCompactions(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the active compaction running on a tablet server
getActiveCompactions(String) - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getActiveCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getActiveScans(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the active scans on tablet server.
getActiveScans(String) - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
getActiveScans(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getActiveScans(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getActiveScans(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getActiveScans(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getAddress(ServerServices.Service) - Method in class org.apache.accumulo.core.util.ServerServices
 
getAddressString(ServerServices.Service) - Method in class org.apache.accumulo.core.util.ServerServices
 
getAge() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getAge() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getAge() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getAge() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAggregator(Key) - Method in class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
Deprecated.
 
getAldOpt(CommandLine) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
getAlgorithmName() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the name of the symmetric algorithm to use for encryption.
getAliasesFromHadoopCredentialProvider(Configuration) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
getAllOptions() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the overall set of options for the CryptoModule.
getAllPropertiesWithPrefix(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
This method returns all properties in a map of string->string under the given prefix property.
getAnyTransport(List<ThriftTransportKey>, boolean) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getAPIVersion() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Get version of BCFile API.
getApplication() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
getArguments() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getArgumentsIterator() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getArgumentsSize() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.Factory
 
getAuthenticationToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getAuthorizationFailures() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
getAuthorizationFailures() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getAuthorizationFailuresMap() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getAuthorizationFailuresSize() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizations() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
Deprecated.
getAuthorizations() - Method in class org.apache.accumulo.core.security.Authorizations
Gets the authorizations in sorted order.
getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getAuthorizationsArray() - Method in class org.apache.accumulo.core.security.Authorizations
Returns a serialized form of these authorizations.
getAuthorizationsBB() - Method in class org.apache.accumulo.core.security.Authorizations
Gets the authorizations in sorted order.
getAuthorizationsContainer() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getAuths() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getAuths(CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
GetAuthsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
GetAuthsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.GetAuthsCommand
 
getAuthTimeout() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getAutoAdjustRanges(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Determines whether a configuration has auto-adjust ranges enabled.
getAutoAdjustRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Determines whether a configuration has auto-adjust ranges enabled.
getAutoAdjustRanges(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Determines whether a configuration has auto-adjust ranges enabled.
getAutoAdjustRanges(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getAverage() - Method in class org.apache.accumulo.core.util.Stat
 
getBackingArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
getBackingArray() - Method in class org.apache.accumulo.core.data.ByteSequence
 
getBadTServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getBadTServersSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getBasePath() - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
 
getBasePath() - Method in interface org.apache.accumulo.core.volume.Volume
The base path which Accumulo will use within the given FileSystem
getBasePath() - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
getBatch() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getBatchFromServer(Instance, Credentials, Range, KeyExtent, String, SortedMap<Key, Value>, SortedSet<Column>, List<IterInfo>, Map<String, Map<String, String>>, int, Authorizations, boolean, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.client.impl.ThriftScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
getBatchSize() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
getBatchSize() - Method in interface org.apache.accumulo.core.client.Scanner
Returns the batch size (number of Key/Value pairs) that will be fetched at a time from a tablet server.
getBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getBatchWriter(String) - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
getBatchWriter(String) - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
 
getBatchWriter(String) - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
Returns a BatchWriter for a particular table.
getBatchWriterConfig() - Method in class org.apache.accumulo.core.cli.BatchWriterOpts
 
getBatchWriterOptions(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Gets the BatchWriterConfig settings.
getBatchWriterOptions(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Gets the BatchWriterConfig settings.
getBatchWriterOptions(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
Gets the BatchWriterConfig settings.
getBatchWriterOptions(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getBCFileVersion() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Get version of BCFile file being read.
getBlock(String) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
Fetch block from cache.
getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get the buffer of the block with the specified name.
getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
 
getBlockCount() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Get the number of data blocks.
getBlockIndexNear(long) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Find the smallest Block index whose starting offset is greater than or equal to the specified offset.
getBlockStreamSize() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the size of the buffering stream that sits above the cipher stream
getBoolean(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getBuffer() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
 
getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
getBuffer() - Method in interface org.apache.accumulo.core.file.blockfile.cache.CacheEntry
 
getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
The byte array returned by this method is only for read optimizations, it should not be modified.
getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getByDepth(int) - Static method in enum org.apache.accumulo.core.data.PartialKey
 
getByteBuffer(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
getBytes() - Method in class org.apache.accumulo.core.data.ComparableBytes
 
getBytes(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
getCachedMetaBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
getCacheFiles(Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
 
getCacheResetCount() - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getCaseSensitive() - Method in class org.apache.accumulo.core.util.shell.Token
 
getCf() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
getChildren() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getCipher() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the initialized cipher object.
getCipher(String) - Static method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModuleUtils
 
getClassLoader(CommandLine, Shell) - Method in class org.apache.accumulo.core.client.mock.MockShell
 
getClassLoader(CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell
 
getClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
getClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
getClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
getClassName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
getClassName() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
Deprecated.
 
getClient() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getClient() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client.Factory
 
getClient() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
 
getClient(TServiceClientFactory<T>, HostAndPort, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
getClient(TServiceClientFactory<T>, String, Property, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
getClient(TServiceClientFactory<T>, String, long, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
getClientConfigFile() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getClientConfiguration() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getClientConfiguration() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getClientNoTimeout(TServiceClientFactory<T>, String, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
getClientProtocol() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getClientString() - Method in class org.apache.accumulo.core.util.TBufferedSocket
 
getCloseUnderylingStreamAfterCryptoStreamClose() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the flag that indicates whether or not to close the underlying stream when the cipher stream is closed.
getCmid() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
getCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
getColFamily() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getColQualifier() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getColumnFamily() - Method in class org.apache.accumulo.core.client.IteratorSetting.Column
 
getColumnFamily() - Method in class org.apache.accumulo.core.data.Column
 
getColumnFamily() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Returns the column
getColumnFamily(Text) - Method in class org.apache.accumulo.core.data.Key
This method gives users control over allocation of Text objects by copying into the passed in text.
getColumnFamily() - Method in class org.apache.accumulo.core.data.Key
This method allocates a Text object and copies into it.
getColumnFamily() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getColumnFamily() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
Deprecated.
 
getColumnFamily() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getColumnFamily() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
getColumnFamilyData() - Method in class org.apache.accumulo.core.data.Key
This method returns a pointer to the keys internal data and does not copy it.
getColumnQualifier() - Method in class org.apache.accumulo.core.client.IteratorSetting.Column
 
getColumnQualifier() - Method in class org.apache.accumulo.core.data.Column
 
getColumnQualifier() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
getColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
This method gives users control over allocation of Text objects by copying into the passed in text.
getColumnQualifier() - Method in class org.apache.accumulo.core.data.Key
This method allocates a Text object and copies into it.
getColumnQualifier() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getColumnQualifier() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
Deprecated.
 
getColumnQualifier() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getColumnQualifier() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
getColumnQualifierData() - Method in class org.apache.accumulo.core.data.Key
This method returns a pointer to the keys internal data and does not copy it.
getColumns() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getColumns() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getColumnVisibility() - Method in class org.apache.accumulo.core.data.Column
 
getColumnVisibility() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
getColumnVisibility() - Method in class org.apache.accumulo.core.data.Key
This method allocates a Text object and copies into it.
getColumnVisibility(Text) - Method in class org.apache.accumulo.core.data.Key
This method gives users control over allocation of Text objects by copying into the passed in text.
getColumnVisibility() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getColumnVisibilityData() - Method in class org.apache.accumulo.core.data.Key
This method returns a pointer to the keys internal data and does not copy it.
getColumnVisibilityParsed() - Method in class org.apache.accumulo.core.data.Key
This method creates a new ColumnVisibility representing the column visibility for this key WARNING: using this method may inhibit performance since a new ColumnVisibility object is created on every call.
getColVisibility() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getCommandNames() - Method in class org.apache.accumulo.core.util.shell.Token
 
getCommands() - Method in class org.apache.accumulo.core.util.shell.ShellExtension
 
getCompactionStrategyOptions(AccumuloConfiguration) - Static method in enum org.apache.accumulo.core.conf.Property
 
getCompressedSize() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
 
getCompressedSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
 
getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Get the compressed size of the block.
getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
Get the compressed size of the block in progress.
getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getCompressionName() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Get the name of the compression algorithm used to compress the block.
getCompressor() - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
getConditions() - Method in class org.apache.accumulo.core.data.ConditionalMutation
 
getConditions() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
getConditionsIterator() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
getConditionsSize() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
getConf() - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
 
getConf() - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
 
getConfig() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
getConfiguration(Instance) - Static method in class org.apache.accumulo.core.client.impl.ServerConfigurationUtil
 
getConfiguration(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
getConfiguration(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getConfiguration() - Method in interface org.apache.accumulo.core.client.Instance
Deprecated.
since 1.6.0. This method makes very little sense in the context of the client API and never should have been exposed.
getConfiguration() - Method in class org.apache.accumulo.core.client.mock.MockInstance
Deprecated.
getConfiguration() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
getConfiguration(String) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
Create a Hadoop Configuration with the appropriate members to access CredentialProviders
getConfiguration(Configuration, String) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
Adds the Credential Provider configuration elements to the provided Configuration.
getConfiguration(JobContext) - Static method in class org.apache.accumulo.core.util.HadoopCompatUtil
Uses reflection to pull Configuration out of the JobContext for Hadoop 1 and Hadoop2 compatibility
getConfiguredBaseDir(AccumuloConfiguration, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
Deprecated.
getConnection(Instance) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
getConnection(Instance) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
getConnection(Instance, boolean) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
getConnection(Instance, boolean, long) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
getConnectionWithRetry(Instance) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
getConnector() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getConnector(String, byte[]) - Method in interface org.apache.accumulo.core.client.Instance
getConnector(String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.Instance
getConnector(String, CharSequence) - Method in interface org.apache.accumulo.core.client.Instance
getConnector(String, AuthenticationToken) - Method in interface org.apache.accumulo.core.client.Instance
Returns a connection to this instance of accumulo.
getConnector(String, byte[]) - Method in class org.apache.accumulo.core.client.mock.MockInstance
Deprecated.
getConnector(String, ByteBuffer) - Method in class org.apache.accumulo.core.client.mock.MockInstance
Deprecated.
getConnector(String, CharSequence) - Method in class org.apache.accumulo.core.client.mock.MockInstance
Deprecated.
getConnector(String, AuthenticationToken) - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getConnector(String, CharSequence) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
getConnector(String, ByteBuffer) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
getConnector(String, AuthenticationToken) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getConnector(String, byte[]) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
getConnector() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getConstrainClass() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getConstrainClass() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
getConstraintViolationSummaries() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getContents() - Method in class org.apache.accumulo.core.util.BinaryTree
 
getCount(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getCount() - Method in class org.apache.accumulo.core.iterators.system.CountingIterator
 
getCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getCq() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
getCredentialProviders(Configuration) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
Wrapper to fetch the configured List<CredentialProvider>s.
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getCryptoModule(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
This method returns a crypto module based on settings in the given configuration parameter.
getCryptoModule(String) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
 
getCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getCurrentFormatter(String, Shell) - Static method in class org.apache.accumulo.core.util.shell.commands.FormatterCommand
 
getCurrentInterpreter(String, Shell) - Static method in class org.apache.accumulo.core.util.shell.commands.InterpreterCommand
 
getCurrentKey() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
 
getCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getCurrentSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get the current size of this cache.
getCurrentValue() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
 
getCv() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
getCve() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getDataBlock(int) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
 
getDataBlock(long, long, long) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
 
getDataBlock(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
It is intended that once the BlockRead object is returned to the caller, that the caller will read the entire block and then call close on the BlockRead class.
getDataBlock(long, long, long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
getDataBlock(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Stream access to a Data Block.
getDataBlock(long, long, long) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
getDataCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getDataCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getDeadTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getDeadTabletServersIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getDeadTabletServersSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getDecompressor() - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
getDecryptingInputStream(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.CryptoModule
Takes a CryptoModuleParameters object containing an InputStream to wrap within a CipherInputStream.
getDecryptingInputStream(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
 
getDeepCopyDataSource(IteratorEnvironment) - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
 
getDefaultCompressionName() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Get the name of the default compression algorithm.
getDefaultConfiguration() - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getDefaultFormatter(Iterable<Map.Entry<Key, Value>>, boolean) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
 
getDefaultInputTableConfig(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Returns the InputTableConfig for the configuration based on the properties set using the single-table input methods.
getDefaultPrompt() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getDefaultTableName(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Gets the default table name from the configuration.
getDefaultTableName(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Gets the default table name from the configuration.
getDefaultTableName(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
Gets the default table name from the configuration.
getDefaultTableName(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getDefaultValue() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
 
getDefaultValue() - Method in enum org.apache.accumulo.core.conf.Property
 
getDefaultVolume(Configuration, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
getDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getDepth() - Method in enum org.apache.accumulo.core.data.PartialKey
 
getDescription() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
 
getDescription() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getDescription() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getDescription() - Method in enum org.apache.accumulo.core.conf.Property
 
getDescription() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getDescription() - Method in enum org.apache.accumulo.core.util.shell.ShellCommandException.ErrorCode
 
getDiskUsage(Set<String>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets the number of bytes being used in the files for a set of tables
getDiskUsage(Set<String>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
getDiskUsage(Set<String>, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
getDiskUsage(Set<String>, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
getDiskUsage(Set<String>, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getDiskUsage(Set<String>, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getDocID(Key) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
getDocID(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getDuplicateReads() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
getElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeLocalUserPassword
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ping
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.success
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.throwsError
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.fails
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.success
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.throwsError
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.beginFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.waitForFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.beginFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.executeFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.finishFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.waitForFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportSplitExtent
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportTabletStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setMasterGoalState
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdown
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdownTabletServer
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getMasterStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.initiateFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportSplitExtent
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportTabletStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setMasterGoalState
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdown
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdownTabletServer
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveScans
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
 
getEncryptedInputStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the encrypted input stream to wrap for decryption.
getEncryptedKey() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the encrypted version of the plaintext key.
getEncryptedOutputStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the encrypted output stream, which is nearly always a wrapped version of the output stream from CryptoModuleParameters.getPlaintextOutputStream().
getEncryptingOutputStream(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.CryptoModule
Takes a CryptoModuleParameters object containing an OutputStream to wrap within a CipherOutputStream.
getEncryptingOutputStream(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
 
getEncryptionMode() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the name of the encryption mode to use for encryption.
getEndKey() - Method in class org.apache.accumulo.core.data.Range
 
getEndRow() - Method in class org.apache.accumulo.core.data.KeyExtent
Returns this extent's end row
getEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
getEndRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
getEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getEndRow(CommandLine) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
getEntries() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getEntriesLeft() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
getEntriesRead() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getEntriesRead() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getEntriesWritten() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getEntriesWritten() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getEquivalent(TablePermission) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
 
getEquivalent(SystemPermission) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
 
getErrorDir() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getErrorServers() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getEstimatedSize() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
getEtcetera() - Method in class org.apache.accumulo.core.util.Version
 
getEvictedCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
getEvictedCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get the number of blocks that have been evicted during the lifetime of this cache.
getEvictionCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
getEvictionCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get the number of eviction runs that have occurred
getEx() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
getExecCommand() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getExecFile() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getExecFileVerbose() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getExit() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getExitCode() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getExportedProps(FileSystem, Path) - Static method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
getExpression() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Accessor for the underlying byte string.
getExtensionName() - Method in class org.apache.accumulo.core.util.shell.ShellExtension
 
getExtent() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getExtent() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getExtent() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getExtent() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getExtent() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
getFail() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getFailedExtents() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getFailedExtentsSize() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getFailures() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getFailuresSize() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getFamily() - Method in class org.apache.accumulo.core.data.Condition
 
getFetchedColumns() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
getFetchedColumns(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Gets the columns to be mapped over from this job.
getFetchedColumns(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Gets the columns to be mapped over from this job.
getFetchedColumns() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Returns the columns to be fetched for this configuration
getFetchedColumns(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Gets the columns to be mapped over from this job.
getFetchedColumns(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getFetchedColumns() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
 
getFieldValue(ClientService.authenticate_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
getFieldValue(ClientService.authenticate_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
getFieldValue(ClientService.authenticateUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
getFieldValue(ClientService.authenticateUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
getFieldValue(ClientService.bulkImportFiles_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getFieldValue(ClientService.bulkImportFiles_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
getFieldValue(ClientService.changeAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getFieldValue(ClientService.changeAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
getFieldValue(ClientService.changeLocalUserPassword_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
getFieldValue(ClientService.changeLocalUserPassword_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
getFieldValue(ClientService.checkClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
getFieldValue(ClientService.checkClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
getFieldValue(ClientService.checkNamespaceClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
getFieldValue(ClientService.checkNamespaceClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
getFieldValue(ClientService.checkTableClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
getFieldValue(ClientService.checkTableClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
getFieldValue(ClientService.createLocalUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
getFieldValue(ClientService.createLocalUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
getFieldValue(ClientService.dropLocalUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
getFieldValue(ClientService.dropLocalUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
getFieldValue(ClientService.getConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
getFieldValue(ClientService.getConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
getFieldValue(ClientService.getDiskUsage_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
getFieldValue(ClientService.getDiskUsage_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
getFieldValue(ClientService.getInstanceId_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
getFieldValue(ClientService.getInstanceId_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
getFieldValue(ClientService.getNamespaceConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
getFieldValue(ClientService.getNamespaceConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
getFieldValue(ClientService.getRootTabletLocation_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
getFieldValue(ClientService.getRootTabletLocation_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
getFieldValue(ClientService.getTableConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
getFieldValue(ClientService.getTableConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
getFieldValue(ClientService.getUserAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
getFieldValue(ClientService.getUserAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
getFieldValue(ClientService.getZooKeepers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
getFieldValue(ClientService.getZooKeepers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
getFieldValue(ClientService.grantNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
getFieldValue(ClientService.grantNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
getFieldValue(ClientService.grantSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
getFieldValue(ClientService.grantSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
getFieldValue(ClientService.grantTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
getFieldValue(ClientService.grantTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
getFieldValue(ClientService.hasNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
getFieldValue(ClientService.hasNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
getFieldValue(ClientService.hasSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
getFieldValue(ClientService.hasSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
getFieldValue(ClientService.hasTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
getFieldValue(ClientService.hasTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
getFieldValue(ClientService.isActive_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
getFieldValue(ClientService.isActive_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
getFieldValue(ClientService.listLocalUsers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
getFieldValue(ClientService.listLocalUsers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
getFieldValue(ClientService.ping_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
getFieldValue(ClientService.ping_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
getFieldValue(ClientService.revokeNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
getFieldValue(ClientService.revokeNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
getFieldValue(ClientService.revokeSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
getFieldValue(ClientService.revokeSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
getFieldValue(ClientService.revokeTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
getFieldValue(ClientService.revokeTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
getFieldValue(TDiskUsage._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
getFieldValue(ThriftSecurityException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
getFieldValue(ThriftTableOperationException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getFieldValue(ThriftTest.fails_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
getFieldValue(ThriftTest.fails_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
getFieldValue(ThriftTest.success_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
getFieldValue(ThriftTest.success_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
getFieldValue(ThriftTest.throwsError_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
getFieldValue(ThriftTest.throwsError_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
getFieldValue(InitialMultiScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
getFieldValue(InitialScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
getFieldValue(IterInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
getFieldValue(MapFileInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
getFieldValue(MultiScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getFieldValue(ScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
getFieldValue(TCMResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
getFieldValue(TColumn._Fields) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getFieldValue(TCondition._Fields) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
getFieldValue(TConditionalMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
getFieldValue(TConditionalSession._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
getFieldValue(TConstraintViolationSummary._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
getFieldValue(TKey._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getFieldValue(TKeyExtent._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
getFieldValue(TKeyValue._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
getFieldValue(TMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getFieldValue(TRange._Fields) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
getFieldValue(UpdateErrors._Fields) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getFieldValue(GcCycleStats._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getFieldValue(GCMonitorService.getStatus_args._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getFieldValue(GCMonitorService.getStatus_result._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getFieldValue(GCStatus._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getFieldValue(Compacting._Fields) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getFieldValue(DeadServer._Fields) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
getFieldValue(FateService.beginFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
getFieldValue(FateService.beginFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
getFieldValue(FateService.executeFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getFieldValue(FateService.executeFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
getFieldValue(FateService.finishFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
getFieldValue(FateService.finishFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
getFieldValue(FateService.waitForFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
getFieldValue(FateService.waitForFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
getFieldValue(MasterClientService.getMasterStats_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
getFieldValue(MasterClientService.getMasterStats_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
getFieldValue(MasterClientService.initiateFlush_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
getFieldValue(MasterClientService.initiateFlush_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
getFieldValue(MasterClientService.removeNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
getFieldValue(MasterClientService.removeNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
getFieldValue(MasterClientService.removeSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
getFieldValue(MasterClientService.removeSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
getFieldValue(MasterClientService.removeTableProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
getFieldValue(MasterClientService.removeTableProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
getFieldValue(MasterClientService.reportSplitExtent_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
getFieldValue(MasterClientService.reportTabletStatus_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
getFieldValue(MasterClientService.setMasterGoalState_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
getFieldValue(MasterClientService.setMasterGoalState_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
getFieldValue(MasterClientService.setNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
getFieldValue(MasterClientService.setNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
getFieldValue(MasterClientService.setSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
getFieldValue(MasterClientService.setSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
getFieldValue(MasterClientService.setTableProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
getFieldValue(MasterClientService.setTableProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
getFieldValue(MasterClientService.shutdown_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
getFieldValue(MasterClientService.shutdown_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
getFieldValue(MasterClientService.shutdownTabletServer_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
getFieldValue(MasterClientService.shutdownTabletServer_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
getFieldValue(MasterClientService.waitForFlush_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
getFieldValue(MasterClientService.waitForFlush_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
getFieldValue(MasterMonitorInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getFieldValue(RecoveryException._Fields) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
getFieldValue(RecoveryStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getFieldValue(TableInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getFieldValue(TabletServerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getFieldValue(TabletSplit._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
getFieldValue(TCredentials._Fields) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
getFieldValue(ActionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getFieldValue(ActiveCompaction._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getFieldValue(ActiveScan._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getFieldValue(ConstraintViolationException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
getFieldValue(IteratorConfig._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getFieldValue(NoSuchScanIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
getFieldValue(NotServingTabletException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
getFieldValue(TabletClientService.applyUpdates_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getFieldValue(TabletClientService.bulkImport_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getFieldValue(TabletClientService.bulkImport_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getFieldValue(TabletClientService.chop_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getFieldValue(TabletClientService.closeConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
getFieldValue(TabletClientService.closeMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
getFieldValue(TabletClientService.closeMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
getFieldValue(TabletClientService.closeScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
getFieldValue(TabletClientService.closeUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
getFieldValue(TabletClientService.closeUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
getFieldValue(TabletClientService.compact_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getFieldValue(TabletClientService.conditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getFieldValue(TabletClientService.conditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getFieldValue(TabletClientService.continueMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
getFieldValue(TabletClientService.continueMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
getFieldValue(TabletClientService.continueScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
getFieldValue(TabletClientService.continueScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
getFieldValue(TabletClientService.fastHalt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
getFieldValue(TabletClientService.flush_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getFieldValue(TabletClientService.flushTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getFieldValue(TabletClientService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
getFieldValue(TabletClientService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getFieldValue(TabletClientService.getActiveScans_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
getFieldValue(TabletClientService.getActiveScans_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
getFieldValue(TabletClientService.getHistoricalStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
getFieldValue(TabletClientService.getHistoricalStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
getFieldValue(TabletClientService.getTabletServerStatus_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
getFieldValue(TabletClientService.getTabletServerStatus_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
getFieldValue(TabletClientService.getTabletStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getFieldValue(TabletClientService.getTabletStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getFieldValue(TabletClientService.halt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
getFieldValue(TabletClientService.halt_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
getFieldValue(TabletClientService.invalidateConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
getFieldValue(TabletClientService.invalidateConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
getFieldValue(TabletClientService.loadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getFieldValue(TabletClientService.removeLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getFieldValue(TabletClientService.splitTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getFieldValue(TabletClientService.splitTablet_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
getFieldValue(TabletClientService.startConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getFieldValue(TabletClientService.startConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
getFieldValue(TabletClientService.startMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getFieldValue(TabletClientService.startMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
getFieldValue(TabletClientService.startScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getFieldValue(TabletClientService.startScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
getFieldValue(TabletClientService.startUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
getFieldValue(TabletClientService.startUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
getFieldValue(TabletClientService.unloadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getFieldValue(TabletClientService.update_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getFieldValue(TabletClientService.update_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getFieldValue(TabletStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getFieldValue(TIteratorSetting._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getFieldValue(TooManyFilesException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
getFilenames() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getFilenamesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getFilenamesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getFiles() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getFilesIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getFileSize(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations
 
getFileSize(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
getFileSize(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
getFilesSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getFileSystem() - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
getFileSystem() - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
 
getFileSystem() - Method in interface org.apache.accumulo.core.volume.Volume
A FileSystem that Accumulo will use
getFileSystem() - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
getFinished() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getFirst() - Method in class org.apache.accumulo.core.util.Pair
 
getFirstKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getFirstKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getFirstKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getFirstKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getFirstKey() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
getFirstKey() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
getFixedProperties() - Static method in enum org.apache.accumulo.core.conf.Property
 
getFlushID() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
getFormatter(Class<? extends Formatter>, Iterable<Map.Entry<Key, Value>>, boolean) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
 
getFormatter(CommandLine, String, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
getFormatter() - Method in class org.apache.accumulo.core.util.shell.Shell
Return the formatter for the current table.
getFormatter(String) - Method in class org.apache.accumulo.core.util.shell.Shell
Return the formatter for the given table.
getFraction(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getFraction(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getFreeSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get the current size of this cache.
getFromHadoopCredentialProvider(Configuration, String) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
getFullScans() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getFullScansIterator() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getFullScansSize() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getGoalState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
GetGroupsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
GetGroupsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.GetGroupsCommand
 
getHadoopConfiguration() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getHistoricalStats(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getHistoricalStats(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getHistoricalStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getHistoricalStats(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getHitCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
getHitRatio() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
getHoldTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
getId() - Method in enum org.apache.accumulo.core.security.NamespacePermission
Gets the byte ID of this permission.
getId() - Method in enum org.apache.accumulo.core.security.SystemPermission
Gets the byte ID of this permission.
getId() - Method in enum org.apache.accumulo.core.security.TablePermission
Gets the byte ID of this permission.
getIdleTime() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getIdleTime() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getIdleTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getIdToNameMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
 
getIdToNameMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getIndex(Class<T>) - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
 
getIndex() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
getIndex() - Method in interface org.apache.accumulo.core.file.blockfile.cache.CacheEntry
 
getIndex(Class<T>) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
 
getIndex(Class<T>) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getIndex(ABlockReader, MultiLevelIndex.IndexEntry) - Static method in class org.apache.accumulo.core.file.rfile.BlockIndex
 
getIndex() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getIndexCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getIndexCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getIndexInfo(Map<Integer, Long>, Map<Integer, Long>) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
getIngestByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getIngestRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getIngestRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getInitializationVector() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the initialization vector to use for this crypto module.
getInputFiles() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getInputFiles() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getInputFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputFilesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputTableConfig(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Fetches a InputTableConfig that has been set on the configuration for a specific table.
getInputTableConfig(JobContext, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Fetches a InputTableConfig that has been set on the configuration for a specific table.
getInputTableConfig(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Returns the InputTableConfig for the given table
getInputTableConfigs(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Fetches all InputTableConfigs that have been set on the given Hadoop job.
getInputTableConfigs(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Fetches all InputTableConfigs that have been set on the given job.
getInputTableConfigs(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Returns all InputTableConfig objects associated with this job.
getInputTableName(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Gets the table name from the configuration.
getInputTableName(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Gets the table name from the configuration.
getInputTableName(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Sets the name of the input table, over which this job will scan.
getInputTableName(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getInstance() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getInstance() - Method in class org.apache.accumulo.core.client.Connector
Accessor method for internal instance object.
getInstance() - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
getInstance() - Static method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getInstance(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Initializes an Accumulo Instance based on the configuration.
getInstance(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Initializes an Accumulo Instance based on the configuration.
getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Initializes an Accumulo Instance based on the configuration.
getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Initializes an Accumulo Instance based on the configuration.
getInstance(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Initializes an Accumulo Instance based on the configuration.
getInstance(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getInstance() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getInstance() - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
getInstance() - Static method in class org.apache.accumulo.core.conf.DefaultConfiguration
Gets a default configuration.
getInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getInstance() - Static method in class org.apache.accumulo.core.file.FileOperations
 
getInstance() - Static method in class org.apache.accumulo.core.util.CachedConfiguration
 
getInstance() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getInstanceId(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
getInstanceId(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
getInstanceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getInstanceId() - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getInstanceID() - Method in interface org.apache.accumulo.core.client.Instance
Returns a unique string that identifies this instance of accumulo.
getInstanceID() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getInstanceID() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getInstanceId() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
getInstanceIDFromHdfs(Path, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
Utility to support certain client side utilities to minimize command-line options.
getInstanceIDFromHdfs(Path, AccumuloConfiguration, Configuration) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
getInstanceName() - Method in interface org.apache.accumulo.core.client.Instance
Returns the instance name given at system initialization time.
getInstanceName() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getInstanceName() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getInstanceName() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
getInterpreter(CommandLine, String, Shell) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
getInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getIterator() - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
 
getIteratorClass() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the name of the class that implements the iterator.
getIteratorClass() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getIterators() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getIterators() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getIterators(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
getIterators(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
getIterators() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Returns the iterators to be set on this configuration
getIterators(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
getIterators(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getIterators() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getIterators() - Method in class org.apache.accumulo.core.data.Condition
 
getIterators() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
getIterators() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIteratorScope() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Get the settings for an iterator.
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Get the settings for an iterator.
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
getIteratorsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIteratorsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIterName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
getKey() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
 
getKey() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getKey() - Method in enum org.apache.accumulo.core.conf.Property
 
getKey() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
getKey() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getKey() - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
getKeyEncryptionStrategyClass() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the key encryption strategy class.
getKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getKeyExtentsForRange(Text, Text, Set<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
Deprecated.
this method not intended for public use and is likely to be removed in a future version.
getKeyLength() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the length of the secret key.
getKeyPrefix() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates the prefix of keys that will be transformed by this iterator.
getKeys(Configuration) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
Attempt to extract all aliases from any configured CredentialsProviders.
getKeyStorePass() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getKeyStorePath() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getKeyStoreType() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getKVCount() - Method in class org.apache.accumulo.core.client.RowIterator
Get a count of the total number of entries in all rows read so far.
getLast() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getLastContact() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLastContactTime() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getLastContactTime() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getLastKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getLastKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getLastKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getLastKey() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
getLastKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getLastKey() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
getLastKey() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
getLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getLastStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
getLeft() - Method in class org.apache.accumulo.core.util.BinaryTree
 
getLength() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
This implementation of length is only an estimate, it does not provide exact values.
getLength() - Method in class org.apache.accumulo.core.data.ComparableBytes
 
getLength() - Method in class org.apache.accumulo.core.data.Key
Returns the sums of the lengths of the row, column family, column qualifier, and visibility.
getlength(int) - Static method in class org.apache.accumulo.core.util.format.BinaryFormatter
 
getList() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
Get a sorted List of all elements in this queue, in descending order.
getLocalCacheFiles(Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
 
getLocalityGroup() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getLocalityGroup() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getLocalityGroup() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getLocalityGroups(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets the locality groups currently set for a table.
getLocalityGroups(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Gets the locality groups currently set for a table.
getLocalityGroups() - Method in class org.apache.accumulo.core.client.mock.MockTable
 
getLocalityGroups(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
getLocation(Instance) - Static method in class org.apache.accumulo.core.util.MonitorUtil
 
getLocationless() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocations
 
getLocations() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocations
 
getLocations() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getLocator(Instance, Text) - Static method in class org.apache.accumulo.core.client.impl.TabletLocator
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getLogLevel(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Gets the log level from this configuration.
getLogLevel(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Gets the log level from this configuration.
getLogLevel(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Gets the log level from this configuration.
getLogLevel(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Gets the log level from this configuration.
getLogLevel(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Gets the log level from this configuration.
getLogLevel(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getLogLevel() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getLogSorts() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLogSortsIterator() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLogSortsSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLookups() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getMajor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Get the major version.
getMajors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getMajors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getMajorVersion() - Method in class org.apache.accumulo.core.util.Version
 
getMask() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getMasterLocations() - Method in interface org.apache.accumulo.core.client.Instance
Returns the location(s) of the accumulo master and any redundant servers.
getMasterLocations() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getMasterLocations() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getMasterStats(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
getMasterStats(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
getMasterStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
getMasterStats(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
getMax() - Method in class org.apache.accumulo.core.util.Stat
 
getMaxFilesPerTablet() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getMaxLatency(TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxLoops() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
getMaxMemory() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxRow(String, Authorizations, Text, boolean, Text, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Finds the max row within a given range.
getMaxRow(String, Authorizations, Text, boolean, Text, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
getMaxSize() - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
Get the maximum size of this cache.
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get the maximum size of this cache.
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
 
getMaxWriteThreads() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxWriteThreads() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getMemoryInBytes(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getMemoryInBytes(String) - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getMessage() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getMessage() - Method in exception org.apache.accumulo.core.master.MasterNotRunningException
 
getMessage() - Method in exception org.apache.accumulo.core.security.VisibilityParseException
 
getMessage() - Method in exception org.apache.accumulo.core.util.shell.ShellCommandException
 
getMetaBlock(String) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
 
getMetaBlock(long, long, long) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
 
getMetaBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
It is intended that once the BlockRead object is returned to the caller, that the caller will read the entire block and then call close on the BlockRead class.
getMetaBlock(long, long, long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
getMetaBlock(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Stream access to a Meta Block.
getMetadataEntry() - Method in class org.apache.accumulo.core.data.KeyExtent
Returns a String representing this extent's entry in the Metadata table
getMetadataEntry(Text, Text) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
getMetadataEntry(KeyExtent) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
getMetadataLocationEntries(SortedMap<Key, Value>) - Static method in class org.apache.accumulo.core.metadata.MetadataLocationObtainer
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getMetaStore(String) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getMetaStore(String) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
getMetaStore(String) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
getMin() - Method in class org.apache.accumulo.core.util.Stat
 
getMinor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Get the minor version.
getMinors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getMinors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getMinorVersion() - Method in class org.apache.accumulo.core.util.Version
 
getMissCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
getMissRatio() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
getMutation() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
 
getMutation() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
getMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getMutations() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletServerMutations
 
getMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getMutationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getMutationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getMutationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getName() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the iterator's name.
getName() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
getName() - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
getName() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getName() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getName() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getName() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getName() - Method in class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
getName() - Method in class org.apache.accumulo.core.util.shell.commands.HiddenCommand
 
getName() - Method in class org.apache.accumulo.core.util.shell.commands.QuestionCommand
 
getName() - Method in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
getName() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
getNamedOptions() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getNamespace() - Method in class org.apache.accumulo.core.client.mock.MockTable
 
getNamespaceConfiguration(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
getNamespaceConfiguration(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
getNamespaceConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getNamespaceConfiguration(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getNamespaceId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
 
getNamespaceId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
Returns the namespace id for a given table ID.
getNamespaceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
getNamespaceName(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
 
getNamespaceName() - Method in class org.apache.accumulo.core.client.mock.MockTable
 
getNamespaceName() - Method in exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
getNamespaceName() - Method in exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
getNamespaceOpt(CommandLine, Shell) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
getNameToIdMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
 
getNameToIdMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getNewDataSource() - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
 
getNewFileExtension(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.FileOperations
 
getNewTablets() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
getNewTabletsIterator() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
getNewTabletsSize() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
getNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
getNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
getNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getNum() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
getNumEntries() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getNumEntries() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getObject(Key) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
getObservers() - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
Gets the current set of observers.
getOffset() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getOldTablet() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
getOnlineTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getOp() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getOp() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getOpaqueKeyEncryptionKeyID() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the opaque ID associated with the encrypted version of the plaintext key.
getOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
getOptions() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the configuration parameters for this iterator.
getOptions() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.AboutCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.AddAuthsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.AddSplitsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.CloneTableCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.CompactCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ConfigCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ConstraintCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.CreateNamespaceCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.CreateTableCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.CreateUserCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteManyCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteNamespaceCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteRowsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteScanIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteShellIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteTableCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.DUCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.EGrepCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ExecfileCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ExportTableCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.FateCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.FlushCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.FormatterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.GetAuthsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.GetGroupsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.GetSplitsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.GrantCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.GrepCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.HelpCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.HistoryCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.InsertCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ListCompactionsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ListIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ListScansCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ListShellIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.MergeCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.NamespacesCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.OfflineCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.OnlineCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.PasswdCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.PingCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.RevokeCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.SetAuthsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.SetGroupsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.SetIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.SetScanIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.SetShellIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.ShellPluginConfigurationCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.TablesCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.commands.UserPermissionsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
getOptionsSize() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getOptionsWithHelp() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
getOsLoad() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getOutputFile() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getOutputFile() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getOutputFile(CommandLine) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
getOverrideStreamsSecretKeyEncryptionStrategy() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the flag that indicates if the underlying stream's key encryption strategy should be overridden by the currently configured key encryption strategy.
getPackage() - Method in class org.apache.accumulo.core.util.Version
 
getPadding() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the name of the padding type to use for encryption.
getParent() - Method in class org.apache.accumulo.core.util.BinaryTree
 
getParseTree() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Gets the parse tree for this column visibility.
getPartition(Key, Writable, int) - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
 
getPartition(Text, Writable, int) - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
 
getPartition(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getPartNextKey() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getPartScan() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
getPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
getPassword() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
getPassword() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getPath(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Gets the permission matching the given byte ID.
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.SystemPermission
Gets the permission matching the given byte ID.
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.TablePermission
Gets the permission matching the given byte ID.
getPlaintextInputStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the plaintext input stream, which is nearly always a wrapped version of the output from CryptoModuleParameters.getEncryptedInputStream().
getPlaintextKey() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the plaintext secret key.
getPlaintextOutputStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the plaintext output stream to wrap for encryption.
getPluginClass(String, Shell, Class<T>, Property) - Static method in class org.apache.accumulo.core.util.shell.commands.ShellPluginConfigurationCommand
 
getPort(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getPort() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
getPos() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
 
getPosition() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
Get the file position.
getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
 
getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
getPrevEndRow() - Method in class org.apache.accumulo.core.data.KeyExtent
Return the previous extent's end row
getPrevEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
getPrevKey() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
getPrevRowUpdateMutation() - Method in class org.apache.accumulo.core.data.KeyExtent
Returns a String representing the previous extent's entry in the Metadata table
getPrevRowUpdateMutation(KeyExtent) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
getPrincipal(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Gets the user name from the configuration.
getPrincipal(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Gets the principal from the configuration.
getPrincipal(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Gets the user name from the configuration.
getPrincipal(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Gets the user name from the configuration.
getPrincipal(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Gets the user name from the configuration.
getPrincipal(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getPrincipal() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getPrincipal() - Method in class org.apache.accumulo.core.security.Credentials
Gets the principal.
getPrincipal() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
getPrincipal() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getPrintableTableIdFromName(Map<String, String>, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getPrintableTableInfoFromId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getPrintableTableInfoFromName(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getPrintableTableNameFromId(Map<String, String>, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getPriority() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get layer at which this iterator applies.
getPriority() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
getPriority() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
getPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getProgress() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
 
getProgress() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
 
getProgress(ByteSequence, ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getProgress(Key) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getProperties(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Gets properties of a namespace, which are inherited by tables in this namespace.
getProperties(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets properties of a table.
getProperties(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
getProperties(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Gets properties of a table
getProperties() - Method in interface org.apache.accumulo.core.client.security.tokens.AuthenticationToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
getProperties(Map<String, String>, AccumuloConfiguration.PropertyFilter) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getProperties(Map<String, String>, AccumuloConfiguration.PropertyFilter) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
getProperties(Map<String, String>, AccumuloConfiguration.PropertyFilter) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
getProperties(Map<String, String>, AccumuloConfiguration.PropertyFilter) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getProperties() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getPropertiesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getProperty(IteratorUtil.IteratorScope) - Static method in enum org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
Fetch the correct configuration key prefix for the given scope.
getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
getPropertyByKey(String) - Static method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
 
getPropertyByKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
 
getProtocol(TTransport) - Method in class org.apache.accumulo.core.util.ThriftUtil.TraceProtocolFactory
 
getQualifier() - Method in class org.apache.accumulo.core.data.Condition
 
getQueryByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getQueryRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getQueryRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getQueued() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getRandomNumberGenerator() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the random number generator name.
getRandomNumberGeneratorProvider() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the random number generator provider name.
getRange() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getRange() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
getRange() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
getRange() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getRange() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getRange() - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
getRange() - Method in interface org.apache.accumulo.core.client.Scanner
Returns the range of keys to scan over.
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
getRange(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
getRange() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getRange(CommandLine, ScanInterpreter) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
getRanges(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Gets the ranges to scan over from a job.
getRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Gets the ranges to scan over from a job.
getRanges() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Returns the ranges to be queried in the configuration
getRanges(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Gets the ranges to scan over from a job.
getRanges(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getRawDefaultValue() - Method in enum org.apache.accumulo.core.conf.Property
 
getRawSize() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
 
getRawSize() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
 
getRawSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
Size is the size of the bytearray that was read form the cache
getRawSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
 
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Get the uncompressed size of the block.
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
Get the raw size of the block.
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
getReadaheadThreshold() - Method in interface org.apache.accumulo.core.client.Scanner
The number of batches of Key/Value pairs returned before the Scanner will begin to prefetch the next batch
getReadaheadThreshold() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getReader() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getReason() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getReason() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getReason() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getReconnectionDelay() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
getRecordParametersToStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the flag that indicates whether or not the module should record its cryptographic parameters to the stream automatically, or rely on the calling code to do so.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloMultiTableInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloRowInputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getRecs() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getRecsInMemory() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getReleaseVersion() - Method in class org.apache.accumulo.core.util.Version
 
getRemoteHost() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
getRemoteSpan(Map.Entry<Key, Value>) - Static method in class org.apache.accumulo.core.trace.TraceFormatter
 
getRequestCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticate_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticateUser_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.bulkImportFiles_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeAuthorizations_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkClass_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkTableClass_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.createLocalUser_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.dropLocalUser_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getDiskUsage_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getInstanceId_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getTableConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getZooKeepers_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantTablePermission_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasTablePermission_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.isActive_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.listLocalUsers_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.ping_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeTablePermission_call
 
getResult(I, ClientService.authenticate_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
 
getResult(I, ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
 
getResult(I, ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
 
getResult(I, ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
 
getResult(I, ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeLocalUserPassword
 
getResult(I, ClientService.checkClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
 
getResult(I, ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
 
getResult(I, ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
 
getResult(I, ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
 
getResult(I, ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
 
getResult(I, ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
 
getResult(I, ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
 
getResult(I, ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
 
getResult(I, ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
 
getResult(I, ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
 
getResult(I, ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
 
getResult(I, ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
 
getResult(I, ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
 
getResult(I, ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
 
getResult(I, ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
 
getResult(I, ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
 
getResult(I, ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
 
getResult(I, ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
 
getResult(I, ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
 
getResult(I, ClientService.isActive_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
 
getResult(I, ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
 
getResult(I, ClientService.ping_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ping
 
getResult(I, ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeNamespacePermission
 
getResult(I, ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeSystemPermission
 
getResult(I, ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeTablePermission
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.fails_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.success_call
 
getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.throwsError_call
 
getResult(I, ThriftTest.fails_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.fails
 
getResult(I, ThriftTest.success_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.success
 
getResult(I, ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.throwsError
 
getResult() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
getResult() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
getResult() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
 
getResult(I, GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.beginFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.executeFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.finishFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.waitForFateOperation_call
 
getResult(I, FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.beginFateOperation
 
getResult(I, FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.executeFateOperation
 
getResult(I, FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.finishFateOperation
 
getResult(I, FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.waitForFateOperation
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getMasterStats_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.initiateFlush_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeNamespaceProperty_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeSystemProperty_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeTableProperty_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.reportSplitExtent_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.reportTabletStatus_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setMasterGoalState_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setNamespaceProperty_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setSystemProperty_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setTableProperty_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.shutdown_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.shutdownTabletServer_call
 
getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.waitForFlush_call
 
getResult(I, MasterClientService.getMasterStats_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getMasterStats
 
getResult(I, MasterClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.initiateFlush
 
getResult(I, MasterClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeNamespaceProperty
 
getResult(I, MasterClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeSystemProperty
 
getResult(I, MasterClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeTableProperty
 
getResult(I, MasterClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportSplitExtent
 
getResult(I, MasterClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportTabletStatus
 
getResult(I, MasterClientService.setMasterGoalState_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setMasterGoalState
 
getResult(I, MasterClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setNamespaceProperty
 
getResult(I, MasterClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setSystemProperty
 
getResult(I, MasterClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setTableProperty
 
getResult(I, MasterClientService.shutdown_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdown
 
getResult(I, MasterClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdownTabletServer
 
getResult(I, MasterClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForFlush
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.applyUpdates_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.bulkImport_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.chop_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compact_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.conditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.fastHalt_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flush_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flushTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveScans_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getHistoricalStats_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletServerStatus_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletStats_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.halt_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.invalidateConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.loadTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.removeLogs_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.splitTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.unloadTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.update_call
 
getResult(I, TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
 
getResult(I, TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
 
getResult(I, TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
 
getResult(I, TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
 
getResult(I, TabletClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeMultiScan
 
getResult(I, TabletClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeScan
 
getResult(I, TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
 
getResult(I, TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
 
getResult(I, TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
 
getResult(I, TabletClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueMultiScan
 
getResult(I, TabletClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueScan
 
getResult(I, TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
 
getResult(I, TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
 
getResult(I, TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
 
getResult(I, TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
 
getResult(I, TabletClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveScans
 
getResult(I, TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
 
getResult(I, TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
 
getResult(I, TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
 
getResult(I, TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
 
getResult(I, TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
 
getResult(I, TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
 
getResult(I, TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
 
getResult(I, TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
 
getResult(I, TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
 
getResult(I, TabletClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startMultiScan
 
getResult(I, TabletClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startScan
 
getResult(I, TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
 
getResult(I, TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
 
getResult(I, TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.success
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.throwsError
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.beginFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.waitForFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeNamespaceProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeSystemProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeTableProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportSplitExtent
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportTabletStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setMasterGoalState
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setNamespaceProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setSystemProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setTableProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdown
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdownTabletServer
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForFlush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
 
getResults() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getResults() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
getResultsIterator() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getResultsIterator() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
getResultsSize() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getResultsSize() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
getRight() - Method in class org.apache.accumulo.core.util.BinaryTree
 
getRoot(Instance) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
getRoot(String) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
getRootTabletLocation() - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
getRootTabletLocation(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
getRootTabletLocation(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
getRootTabletLocation() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getRootTabletLocation() - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getRootTabletLocation() - Method in interface org.apache.accumulo.core.client.Instance
Returns the location of the tablet server that is serving the root tablet.
getRootTabletLocation() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getRootTabletLocation() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getRow(Text) - Method in class org.apache.accumulo.core.data.Key
This method gives users control over allocation of Text objects by copying into the passed in text.
getRow() - Method in class org.apache.accumulo.core.data.Key
This method allocates a Text object and copies into it.
getRow() - Method in class org.apache.accumulo.core.data.Mutation
 
getRow() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getRow() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getRow(Text, Text) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
getRow() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getRowData() - Method in class org.apache.accumulo.core.data.Key
This method returns a pointer to the keys internal data and does not copy it.
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
 
getRunning() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getRuntime() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getScanAuthorizations(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Gets the authorizations to set for the scans from the configuration.
getScanAuthorizations(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Gets the authorizations to set for the scans from the configuration.
getScanAuthorizations(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Gets the authorizations to set for the scans from the configuration.
getScanAuthorizations(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getScanid() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getScanid() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
getScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
getScanId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
getScannerIterator() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
getScanRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getScans() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getSecond() - Method in class org.apache.accumulo.core.util.Pair
 
getSecretKeyEncryptionStrategy(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
 
getSecretKeyEncryptionStrategy(String) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
 
getSecs(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
getSecureRandom() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the initialized secure random object.
getSecureRandom(String, String) - Static method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModuleUtils
 
getSecurityErrorCode() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getSerializedFormat() - Method in class org.apache.accumulo.core.data.Mutation
 
getSerialVersion() - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
getServer() - Method in exception org.apache.accumulo.core.client.impl.AccumuloServerException
 
getServer() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
getServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
getServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
getServerProtocols() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getServerSocket(int, int, InetAddress, SslConnectionParams) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
getServersShuttingDown() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getServersShuttingDownIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getServersShuttingDownSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getServicedTableId() - Method in class org.apache.accumulo.core.metadata.MetadataServicer
 
getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
getSessionId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
getSimulationMode(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Determines whether this feature is enabled.
getSimulationMode(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Determines whether this feature is enabled.
getSimulationMode(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
Determines whether this feature is enabled.
getSimulationMode(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getSiteConfiguration() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
 
getSiteConfiguration() - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
getSize() - Method in class org.apache.accumulo.core.data.Key
getSize() - Method in class org.apache.accumulo.core.data.Value
 
getSize() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getSizeIterator(Connector, String, Text, Text) - Method in class org.apache.accumulo.core.util.Merge
 
getSource() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getSpanKey(Map<String, String>) - Method in class org.apache.accumulo.core.trace.ZooTraceClient
 
getSplit() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
getSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getSplits(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Deprecated.
since 1.5.0; use TableOperations.listSplits(String) instead.
getSplits(String, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Deprecated.
since 1.5.0; use TableOperations.listSplits(String, int) instead.
getSplits(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Deprecated.
getSplits(String, int) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Deprecated.
getSplits(JobConf, int) - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Read the metadata table to get tablets and match up ranges to them.
getSplits(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Gets the splits of the tables that have been set on the job.
getSplits(String) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
getSplits() - Method in class org.apache.accumulo.core.client.mock.MockTable
 
getSplits() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
GetSplitsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
GetSplitsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.GetSplitsCommand
 
getSsiList() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getSsiList() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getSsio() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getSsio() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getSslParams() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
 
getStart() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
getStarted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getStartKey() - Method in class org.apache.accumulo.core.data.Range
 
getStartPos() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
 
getStartPos() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
 
getStartPos() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Get the starting position of the block in the file.
getStartPos() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
 
getStartRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
getStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getStartRow(CommandLine) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
getState() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getState() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getState() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
getState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getState() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get counter statistics for this cache.
getStats() - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
Finalize the aggregation and return the result.
getStats() - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
 
getStats() - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
 
getStatus() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
If this method throws an exception, then its possible the mutation is still being actively processed.
getStatus() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
getStatus(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient
 
getStatus(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncIface
 
getStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
getStatus(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.Iface
 
getStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
getStatus() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
getStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getStdDev() - Method in class org.apache.accumulo.core.util.Stat
 
getStop() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
getStream() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
 
getStream() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
 
getStream() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
It is intended that the caller of this method will close the stream we also only intend that this be called once per BlockRead.
getStream() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
 
getSubcommand(String) - Method in class org.apache.accumulo.core.util.shell.Token
 
getSubcommandList() - Method in class org.apache.accumulo.core.util.shell.Token
 
getSubcommandNames() - Method in class org.apache.accumulo.core.util.shell.Token
 
getSubcommandNames(String) - Method in class org.apache.accumulo.core.util.shell.Token
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
getSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
getSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
getSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getSum() - Method in class org.apache.accumulo.core.util.Stat
 
getSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getSupportedAlgorithms() - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Compression
 
getSymbols() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getSymbolsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getSymbolsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getSymbolTable() - Method in class org.apache.accumulo.core.client.impl.CompressedIterators
 
getSysPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
getSystemConfiguration() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
 
getSystemConfiguration() - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getTable() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getTable() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getTable() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
getTable() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
getTableConfiguration(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
getTableConfiguration(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
getTableConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getTableConfiguration(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getTableConfiguration(Connector, String) - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getTableId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
getTableId() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getTableId() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getTableId() - Method in class org.apache.accumulo.core.client.mock.MockTable
 
getTableId() - Method in exception org.apache.accumulo.core.client.TableDeletedException
 
getTableId() - Method in class org.apache.accumulo.core.data.KeyExtent
Returns the extent's table id
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getTableID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getTableIds(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
 
getTableInfo() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getTableMap() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getTableMap() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getTableMapSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getTableMapSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getTableName() - Method in class org.apache.accumulo.core.cli.ClientOnDefaultTable
 
getTableName(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
getTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
getTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
getTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
getTableName() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getTableName() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getTableName() - Method in exception org.apache.accumulo.core.client.TableNotFoundException
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
getTableName() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getTableNames(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
 
getTableOpt(CommandLine, Shell) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
getTables() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
getTables() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
getTables() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
getTables(MockAccumulo) - Method in class org.apache.accumulo.core.client.mock.MockNamespace
 
getTablesIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
getTablesIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
getTablesSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
getTablesSize() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
getTableState(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getTablet() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
getTabletLocations(SortedMap<KeyExtent, String>) - Method in class org.apache.accumulo.core.metadata.MetadataServicer
Populate the provided data structure with the known tablets for the table being serviced
getTabletLocator(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Initializes an Accumulo TabletLocator based on the configuration.
getTabletLocator(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Deprecated.
since 1.6.0
getTabletLocator(JobContext, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Initializes an Accumulo TabletLocator based on the configuration.
getTabletLocator(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Deprecated.
since 1.6.0
getTabletLocator(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Initializes an Accumulo TabletLocator based on the configuration.
getTabletLocator(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getTabletServer() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
 
getTabletServer() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
getTabletServers() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the currently active tablet servers participating in the accumulo instance
getTabletServers() - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
getTabletServerStatus(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getTabletServerStatus(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getTabletServerStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getTabletServerStatus(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getTabletStats(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getTabletStats(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getTabletStats(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getTabletStats(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getTblNspcPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
getTblPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
getTerm(Key) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
getTerm(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTerm(byte[]) - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTermEnd() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTermStart() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTermString() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
 
getTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
getTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getTime() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getTimedOutSevers() - Method in exception org.apache.accumulo.core.client.TimedOutException
 
getTimeInMillis(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getTimeInMillis(String) - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getTimeOut() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
Deprecated.
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getTimeOut() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
Deprecated.
getTimeOut() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
Deprecated.
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
getTimeOut() - Method in class org.apache.accumulo.core.client.IsolatedScanner
Deprecated.
getTimeOut() - Method in class org.apache.accumulo.core.client.mock.MockScanner
Deprecated.
getTimeOut() - Method in interface org.apache.accumulo.core.client.Scanner
getTimeout(TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the setting for how long a scanner will automatically retry when a failure occurs.
getTimeout(CommandLine) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteCommand
 
getTimeout(CommandLine) - Method in class org.apache.accumulo.core.util.shell.commands.InsertCommand
 
getTimeout(CommandLine) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
getTimestamp() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
getTimestamp() - Method in class org.apache.accumulo.core.data.Condition
 
getTimestamp() - Method in class org.apache.accumulo.core.data.Key
 
getTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
getTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
getToAuth() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
getToe() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
getToken() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
getToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
getToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
getToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
getToken(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getToken() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getToken() - Method in class org.apache.accumulo.core.security.Credentials
Gets the authentication token.
getToken() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
getToken() - Method in class org.apache.accumulo.core.util.shell.Shell
 
getTokenClass(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
getTokenClass(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
getTokenClass(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
getTokenClass(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
getTokenClass(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
getTokenClassName() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
getTokenFromFile(Configuration, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Reads from the token file in distributed cache.
getTokenProperties() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getTokens() - Method in class org.apache.accumulo.core.util.shell.commands.QuotedStringTokenizer
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
getTopKey() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
 
getTopKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getTopKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.Combiner
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.DevNull
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
getTopKey() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Returns top key.
getTopKey() - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
 
getTopValue() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getTopValue() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.Combiner
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.DevNull
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
getTopValue() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Returns top value.
getTopValue() - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getTransport(String, long, SslConnectionParams) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getTransportWithDefaultTimeout(HostAndPort, AccumuloConfiguration) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getTrustStorePass() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getTrustStorePath() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getTrustStoreType() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getTs() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
getTServerClient(String, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
getTServerClient(String, AccumuloConfiguration, long) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
getTServerInfo() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getTServerInfoIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getTServerInfoSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getTserverLock() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
getTtl() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
getTTransportParams() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
getType() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getType() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getType() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
 
getType() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
 
getType() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getType() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
getType() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getType() - Method in enum org.apache.accumulo.core.conf.Property
 
getType() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getUnassignedTablets() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getUnknownExceptions() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getUnnamedOptionDescriptions() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getUnrecognizedOptions() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
getUpdates() - Method in class org.apache.accumulo.core.data.Mutation
 
getUsage() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
getUsage() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
getUser() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getUser() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getUser() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
 
getUser() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
getUser() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
 
getUser() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getUserAuthorizations(String) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Retrieves the user's authorizations for scanning
getUserAuthorizations(String) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
getUserAuthorizations(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
getUserAuthorizations(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
getUserAuthorizations(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getUserAuthorizations(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getUsername() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getUUID() - Method in class org.apache.accumulo.core.data.KeyExtent
 
getVal() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
getValidExtensions() - Static method in class org.apache.accumulo.core.file.FileOperations
 
getValue() - Method in enum org.apache.accumulo.core.client.impl.thrift.ConfigurationType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.client.impl.thrift.TableOperation
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
getValue() - Method in class org.apache.accumulo.core.data.Condition
 
getValue() - Method in enum org.apache.accumulo.core.data.thrift.TCMStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
getValue() - Method in enum org.apache.accumulo.core.master.thrift.FateOperation
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
getValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
getValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
getValue() - Method in enum org.apache.accumulo.core.master.thrift.MasterGoalState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.master.thrift.MasterState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.master.thrift.TabletLoadState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionReason
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ScanState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ScanType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValueFromCredentialProvider(Configuration, String) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
Attempt to extract the password from any configured CredentialsProviders for the given alias.
getValues() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getValuesIterator() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getValuesSize() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getVectorSize() - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
getVersion() - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
getViolationCode() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getViolationCode() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
getViolationDescription(short) - Method in interface org.apache.accumulo.core.constraints.Constraint
Implementers of this method should return a short one sentence description of what a given violation code means.
getViolationDescription(short) - Method in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
 
getViolationDescription() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getViolationDescription() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
getViolationDescription(short) - Method in class org.apache.accumulo.core.security.VisibilityConstraint
 
getViolationSummaries() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getViolationSummaries() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
getViolationSummariesIterator() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getViolationSummariesIterator() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
getViolationSummariesSize() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getViolationSummariesSize() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
getVisibility() - Method in class org.apache.accumulo.core.data.Condition
 
getVisibilityCacheSize(Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Gets the valid visibility count for this job.
getVolume(String, Configuration, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
getVolumeUris(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
Compute the URIs to be used by Accumulo
getVolumeUris(AccumuloConfiguration, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
getWhy() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
getZooKeeperHosts() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getZooKeeperInstance() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getZooKeeperInstanceName() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
getZooKeepers(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
getZooKeepers(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
getZooKeepers() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getZooKeepers() - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getZooKeepers() - Method in interface org.apache.accumulo.core.client.Instance
Returns a comma-separated list of zookeeper servers the instance is using.
getZooKeepers() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
getZooKeepers() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getZooKeepers() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getZooKeepersSessionTimeOut() - Method in interface org.apache.accumulo.core.client.Instance
Returns the zookeeper connection timeout.
getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getZooReaderWriter(Instance, String) - Method in class org.apache.accumulo.core.util.shell.commands.FateCommand
 
GLOBAL_CONF_FILENAME - Static variable in class org.apache.accumulo.core.client.ClientConfiguration
 
goalState - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
GrantCommand - Class in org.apache.accumulo.core.util.shell.commands
 
GrantCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.GrantCommand
 
grantNamespacePermission(String, String, NamespacePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Grant a user a specific permission for a specific namespace
grantNamespacePermission(String, String, NamespacePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
grantNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
grantNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
grantNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
grantNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
grantSystemPermission(String, SystemPermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Grant a user a system permission
grantSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
grantSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
grantSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
grantSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
grantSystemPermission(TInfo, TCredentials, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
grantTablePermission(String, String, TablePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Grant a user a specific permission for a specific table
grantTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
grantTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
grantTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
grantTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
grantTablePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
GrepCommand - Class in org.apache.accumulo.core.util.shell.commands
 
GrepCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.GrepCommand
 
GrepIterator - Class in org.apache.accumulo.core.iterators
Deprecated.
since 1.4, replaced by GrepIterator
GrepIterator() - Constructor for class org.apache.accumulo.core.iterators.GrepIterator
Deprecated.
 
GrepIterator - Class in org.apache.accumulo.core.iterators.user
This iterator provides exact string matching.
GrepIterator() - Constructor for class org.apache.accumulo.core.iterators.user.GrepIterator
 

H

HADOOP_CRED_ENTRY_CLASS_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HADOOP_CRED_ENTRY_GET_CREDENTIAL_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HADOOP_CRED_PROVIDER_CLASS_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HADOOP_CRED_PROVIDER_CREATE_CREDENTIAL_ENTRY_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HADOOP_CRED_PROVIDER_FACTORY_CLASS_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HADOOP_CRED_PROVIDER_FACTORY_GET_PROVIDERS_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HADOOP_CRED_PROVIDER_FLUSH_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HADOOP_CRED_PROVIDER_GET_ALIASES_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HADOOP_CRED_PROVIDER_GET_CREDENTIAL_ENTRY_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
 
HadoopCompatUtil - Class in org.apache.accumulo.core.util
Utility to help manage binary compatibility between Hadoop versions 1 and 2.
HadoopCompatUtil() - Constructor for class org.apache.accumulo.core.util.HadoopCompatUtil
 
halt(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
halt(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
halt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
halt(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
hasColumns(Key) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
hasExited() - Method in class org.apache.accumulo.core.util.shell.Shell
 
hash - Variable in class org.apache.accumulo.core.bloomfilter.Filter
The hash function used to map a key to several positions in the vector.
HASH_COUNT - Static variable in class org.apache.accumulo.core.file.BloomFilterLayer
 
hashCode() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
hashCode() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
hashCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
hashCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
 
hashCode() - Method in class org.apache.accumulo.core.client.IteratorSetting
 
hashCode() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
 
hashCode() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
hashCode() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
hashCode() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
hashCode() - Method in class org.apache.accumulo.core.data.ByteSequence
 
hashCode() - Method in class org.apache.accumulo.core.data.Column
 
hashCode() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
hashCode() - Method in class org.apache.accumulo.core.data.Condition
 
hashCode() - Method in class org.apache.accumulo.core.data.ConditionalMutation
 
hashCode() - Method in class org.apache.accumulo.core.data.Key
 
hashCode() - Method in class org.apache.accumulo.core.data.KeyExtent
 
hashCode() - Method in class org.apache.accumulo.core.data.Mutation
 
hashCode() - Method in class org.apache.accumulo.core.data.Range
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
hashCode() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
hashCode() - Method in class org.apache.accumulo.core.data.Value
 
hashCode() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
 
hashCode() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
hashCode() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
hashCode() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
hashCode() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
hashCode() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
hashCode() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
hashCode() - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColFamHashKey
 
hashCode() - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColHashKey
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
hashCode() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
hashCode() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
hashCode() - Method in class org.apache.accumulo.core.security.Authorizations
 
hashCode() - Method in class org.apache.accumulo.core.security.ColumnVisibility
 
hashCode() - Method in class org.apache.accumulo.core.security.Credentials
 
hashCode() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
hashCode() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
hashCode() - Method in class org.apache.accumulo.core.util.Pair
 
hashCode() - Method in class org.apache.accumulo.core.util.ServerServices
 
hashCode() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
hashCode() - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
 
hashType - Variable in class org.apache.accumulo.core.bloomfilter.Filter
Type of hashing function to use.
hasNamespacePermission(String, String, NamespacePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Verify the user has a particular namespace permission
hasNamespacePermission(String, String, NamespacePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
hasNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
hasNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
hasNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
hasNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
hasNext() - Method in class org.apache.accumulo.core.client.impl.ScannerIterator
 
hasNext() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator
 
hasNext() - Method in class org.apache.accumulo.core.client.mock.IteratorAdapter
 
hasNext() - Method in class org.apache.accumulo.core.client.RowIterator
Returns true if there is at least one more row to get.
hasNext() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
hasNext() - Method in class org.apache.accumulo.core.iterators.Combiner.ValueIterator
 
hasNext() - Method in class org.apache.accumulo.core.trace.TraceFormatter
 
hasNext() - Method in class org.apache.accumulo.core.util.format.DateStringFormatter
 
hasNext() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
hasNext() - Method in class org.apache.accumulo.core.util.format.DeleterFormatter
 
hasNext() - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
hasNext() - Method in class org.apache.accumulo.core.util.PeekingIterator
 
hasPrevious() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
hasSystemPermission(String, SystemPermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Verify the user has a particular system permission
hasSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
hasSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
hasSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
hasSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
hasSystemPermission(TInfo, TCredentials, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
hasTablePermission(String, String, TablePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Verify the user has a particular table permission
hasTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
hasTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
hasTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
hasTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
hasTablePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
hasTimestamp() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
hasTimestamp - Variable in class org.apache.accumulo.core.data.thrift.TCondition
 
hasTop() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
 
hasTop() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
hasTop() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
hasTop() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
hasTop() - Method in class org.apache.accumulo.core.iterators.Combiner
 
hasTop() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.DevNull
 
hasTop() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
hasTop() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Returns true if the iterator has more elements.
hasTop() - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
hasTop() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.user.RowFilter
 
hasTop() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
HDFS_TABLES_DIR - Static variable in class org.apache.accumulo.core.Constants
 
HEADER - Static variable in class org.apache.accumulo.core.security.Authorizations
A special header string used when serializing instances of this class.
HeapIterator - Class in org.apache.accumulo.core.iterators.system
Constructs a PriorityQueue of multiple SortedKeyValueIterators.
HeapIterator() - Constructor for class org.apache.accumulo.core.iterators.system.HeapIterator
 
HeapIterator(int) - Constructor for class org.apache.accumulo.core.iterators.system.HeapIterator
 
heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
Total size of all elements in this queue.
HeapSize - Interface in org.apache.accumulo.core.file.blockfile.cache
Implementations can be asked for an estimate of their size in bytes.
heapSize() - Method in interface org.apache.accumulo.core.file.blockfile.cache.HeapSize
 
heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
Help - Class in org.apache.accumulo.core.cli
 
Help() - Constructor for class org.apache.accumulo.core.cli.Help
 
help - Variable in class org.apache.accumulo.core.cli.Help
 
HelpCommand - Class in org.apache.accumulo.core.util.shell.commands
 
HelpCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.HelpCommand
 
helpLongOption - Static variable in class org.apache.accumulo.core.util.shell.ShellOptions
 
helpOption - Static variable in class org.apache.accumulo.core.util.shell.ShellOptions
 
HexFormatter - Class in org.apache.accumulo.core.util.format
A simple formatter that print the row, column family, column qualifier, and value as hex
HexFormatter() - Constructor for class org.apache.accumulo.core.util.format.HexFormatter
 
HexScanInterpreter - Class in org.apache.accumulo.core.util.interpret
As simple scan interpreter that converts hex to binary.
HexScanInterpreter() - Constructor for class org.apache.accumulo.core.util.interpret.HexScanInterpreter
 
HiddenCommand - Class in org.apache.accumulo.core.util.shell.commands
 
HiddenCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.HiddenCommand
 
HISTORY_DIR_NAME - Static variable in class org.apache.accumulo.core.util.shell.Shell
 
HISTORY_FILE_NAME - Static variable in class org.apache.accumulo.core.util.shell.Shell
 
HistoryCommand - Class in org.apache.accumulo.core.util.shell.commands
 
HistoryCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.HistoryCommand
 
hit() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
holdTime - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 

I

id - Variable in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
ID - Static variable in class org.apache.accumulo.core.metadata.MetadataTable
 
ID - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
idleTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
importDirectory(String, String, String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Bulk import all the files in a directory into a table.
importDirectory(String, String, String, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
ImportDirectoryCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ImportDirectoryCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ImportDirectoryCommand
 
importTable(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Imports a table exported via exportTable and copied via hadoop distcp.
importTable(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
ImportTableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ImportTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ImportTableCommand
 
in - Variable in class org.apache.accumulo.core.client.mock.MockShell
 
includeTransformedKey(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Determines whether or not to include transformedKey in the output.
inclusive - Variable in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
increment(KT, long) - Method in class org.apache.accumulo.core.util.MapCounter
 
indexCacheHits - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
indexCacheRequest - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
IndexedDocIterator - Class in org.apache.accumulo.core.iterators.user
This iterator facilitates document-partitioned indexing.
IndexedDocIterator() - Constructor for class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
infiniteStartKey - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
infiniteStopKey - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
InfoCommand - Class in org.apache.accumulo.core.util.shell.commands
 
InfoCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.InfoCommand
 
ingestByteRate - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
ingestRate - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
ingestRate - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
 
init(AuthenticationToken.Properties) - Method in interface org.apache.accumulo.core.client.security.tokens.AuthenticationToken
 
init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Combiner
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DevNull
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Filter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.LongCombiner
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
init(SortedKeyValueIterator<K, V>, Map<String, String>, IteratorEnvironment) - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Initializes the iterator.
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
init(Set<Column>) - Method in class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.CountingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.DeletingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.MultiIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
init(SortedKeyValueIterator<K, V>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
initialize(InputSplit, JobConf) - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
Initialize a scanner over the given input split using this task attempt configuration.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Initialize a scanner over the given input split using this task attempt configuration.
initialize(Iterable<Map.Entry<Key, Value>>, boolean) - Method in class org.apache.accumulo.core.trace.TraceFormatter
 
initialize(Iterable<Map.Entry<Key, Value>>, boolean) - Method in class org.apache.accumulo.core.util.format.DateStringFormatter
 
initialize(Iterable<Map.Entry<Key, Value>>, boolean) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
initialize(Iterable<Map.Entry<Key, Value>>, boolean) - Method in interface org.apache.accumulo.core.util.format.Formatter
 
initialize(Iterable<Map.Entry<Key, Value>>, boolean) - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
initialize(Iterator<E>) - Method in class org.apache.accumulo.core.util.PeekingIterator
Initializes this iterator, to be used with PeekingIterator.PeekingIterator().
initializeCipher(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.CryptoModule
Generates a Cipher object based on the parameters in the given CryptoModuleParameters object and places it into the CryptoModuleParameters.getCipher() property.
initializeCipher(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
 
InitialMultiScan - Class in org.apache.accumulo.core.data.thrift
 
InitialMultiScan() - Constructor for class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
InitialMultiScan(long, MultiScanResult) - Constructor for class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
InitialMultiScan(InitialMultiScan) - Constructor for class org.apache.accumulo.core.data.thrift.InitialMultiScan
Performs a deep copy on other.
InitialMultiScan._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InitialScan - Class in org.apache.accumulo.core.data.thrift
 
InitialScan() - Constructor for class org.apache.accumulo.core.data.thrift.InitialScan
 
InitialScan(long, ScanResult) - Constructor for class org.apache.accumulo.core.data.thrift.InitialScan
 
InitialScan(InitialScan) - Constructor for class org.apache.accumulo.core.data.thrift.InitialScan
Performs a deep copy on other.
InitialScan._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
initiateFlush(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
initiateFlush(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
initiateFlush(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
initiateFlush(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
InputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
 
InputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
 
InputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
InputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
 
InputConfigurator.Features - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
Configuration keys for various features.
InputConfigurator.Features - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
InputConfigurator.ScanOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
Configuration keys for Scanner.
InputConfigurator.ScanOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
inputFiles - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
InputFormatBase<K,V> - Class in org.apache.accumulo.core.client.mapred
This abstract InputFormat class allows MapReduce jobs to use Accumulo as the source of K,V pairs.
InputFormatBase() - Constructor for class org.apache.accumulo.core.client.mapred.InputFormatBase
 
InputFormatBase<K,V> - Class in org.apache.accumulo.core.client.mapreduce
This abstract InputFormat class allows MapReduce jobs to use Accumulo as the source of K,V pairs.
InputFormatBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.InputFormatBase
 
InputFormatBase.RangeInputSplit - Class in org.apache.accumulo.core.client.mapred
Deprecated.
since 1.5.2; Use RangeInputSplit instead.
InputFormatBase.RangeInputSplit() - Constructor for class org.apache.accumulo.core.client.mapred.InputFormatBase.RangeInputSplit
Deprecated.
 
InputFormatBase.RangeInputSplit(InputFormatBase.RangeInputSplit) - Constructor for class org.apache.accumulo.core.client.mapred.InputFormatBase.RangeInputSplit
Deprecated.
 
InputFormatBase.RangeInputSplit(String, String, Range, String[]) - Constructor for class org.apache.accumulo.core.client.mapred.InputFormatBase.RangeInputSplit
Deprecated.
 
InputFormatBase.RangeInputSplit(String, Range, String[]) - Constructor for class org.apache.accumulo.core.client.mapred.InputFormatBase.RangeInputSplit
Deprecated.
 
InputFormatBase.RangeInputSplit - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
since 1.5.2; Use RangeInputSplit instead.
InputFormatBase.RangeInputSplit() - Constructor for class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RangeInputSplit
Deprecated.
 
InputFormatBase.RangeInputSplit(InputFormatBase.RangeInputSplit) - Constructor for class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RangeInputSplit
Deprecated.
 
InputFormatBase.RangeInputSplit(String, Range, String[]) - Constructor for class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RangeInputSplit
Deprecated.
 
InputFormatBase.RangeInputSplit(String, String, Range, String[]) - Constructor for class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RangeInputSplit
Deprecated.
 
InputFormatBase.RecordReaderBase<K,V> - Class in org.apache.accumulo.core.client.mapred
 
InputFormatBase.RecordReaderBase() - Constructor for class org.apache.accumulo.core.client.mapred.InputFormatBase.RecordReaderBase
 
InputFormatBase.RecordReaderBase<K,V> - Class in org.apache.accumulo.core.client.mapreduce
 
InputFormatBase.RecordReaderBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RecordReaderBase
 
InputTableConfig - Class in org.apache.accumulo.core.client.mapreduce
This class to holds a batch scan configuration for a table.
InputTableConfig() - Constructor for class org.apache.accumulo.core.client.mapreduce.InputTableConfig
 
InputTableConfig(DataInput) - Constructor for class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Creates a batch scan config object out of a previously serialized batch scan config object.
InsertCommand - Class in org.apache.accumulo.core.util.shell.commands
 
InsertCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.InsertCommand
 
instance - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
Instance - Interface in org.apache.accumulo.core.client
This class represents the information a client needs to know to connect to an instance of accumulo.
instance - Variable in class org.apache.accumulo.core.trace.InstanceUserPassword
 
instance - Variable in class org.apache.accumulo.core.util.shell.Shell
 
instanceId - Variable in class org.apache.accumulo.core.security.thrift.TCredentials
 
InstanceOperations - Interface in org.apache.accumulo.core.client.admin
 
instanceOperations() - Method in class org.apache.accumulo.core.client.Connector
Retrieves an InstanceOperations object to modify instance configuration.
instanceOperations() - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
instanceOperations() - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
InstanceOperationsImpl - Class in org.apache.accumulo.core.client.admin
Deprecated.
since 1.6.0; not intended for public api and you should not use it.
InstanceOperationsImpl(Instance, TCredentials) - Constructor for class org.apache.accumulo.core.client.admin.InstanceOperationsImpl
Deprecated.
 
InstanceOperationsImpl - Class in org.apache.accumulo.core.client.impl
Provides a class for administering the accumulo instance
InstanceOperationsImpl(Instance, Credentials) - Constructor for class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
InstanceUserPassword - Class in org.apache.accumulo.core.trace
 
InstanceUserPassword(Instance, String, String) - Constructor for class org.apache.accumulo.core.trace.InstanceUserPassword
 
instantiateClassProperty(Property, Class<T>, T) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
INTEGER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for an Integer
IntegerLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for signed integers.
IntegerLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
 
interfaceMatch - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
interfaceMatch - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
interfaceMatch - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
interpretBeginRow(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
interpretBeginRow(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
 
interpretBeginRow(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
 
interpretColumnFamily(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
interpretColumnFamily(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
 
interpretColumnFamily(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
 
interpretColumnQualifier(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
interpretColumnQualifier(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
 
interpretColumnQualifier(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
 
interpretEndRow(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
interpretEndRow(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
 
interpretEndRow(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
 
InterpreterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
InterpreterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.InterpreterCommand
 
interpretRow(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
interpretRow(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
 
interpretRow(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
 
InterruptibleIterator - Interface in org.apache.accumulo.core.iterators.system
 
IntersectingIterator - Class in org.apache.accumulo.core.iterators
Deprecated.
since 1.4, replaced by IntersectingIterator
IntersectingIterator() - Constructor for class org.apache.accumulo.core.iterators.IntersectingIterator
Deprecated.
 
IntersectingIterator - Class in org.apache.accumulo.core.iterators.user
This iterator facilitates document-partitioned indexing.
IntersectingIterator() - Constructor for class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
IntersectingIterator.TermSource - Class in org.apache.accumulo.core.iterators.user
 
IntersectingIterator.TermSource(IntersectingIterator.TermSource) - Constructor for class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
IntersectingIterator.TermSource(SortedKeyValueIterator<Key, Value>, Text) - Constructor for class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
IntersectingIterator.TermSource(SortedKeyValueIterator<Key, Value>, Text, boolean) - Constructor for class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
inUse - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
invalidateCache(String) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
invalidateCache() - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
 
invalidateCache() - Method in class org.apache.accumulo.core.client.impl.TabletLocator
Invalidate entire cache
invalidateCache(String) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
Invalidate all metadata entries that point to server
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
invalidateCache(String) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
invalidateCache() - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
invalidateCache(String) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletServerLockChecker
 
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
 
invalidateCache() - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
 
invalidateCache(String) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
 
invalidateCache(String) - Method in class org.apache.accumulo.core.client.impl.ZookeeperLockChecker
 
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
 
invalidateCache() - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
 
invalidateCache(String) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
 
invalidateCache() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
invalidateConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
invalidateConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
invalidateConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
invalidateConditionalUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
invalidMessage(T) - Method in class org.apache.accumulo.core.util.ArgumentChecker.Validator
 
isActive(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
isActive(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
isActive(TInfo, long) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
isActive(TInfo, long) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
isAdvertiseViaMulticastDNS() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
isAuthTimeoutDisabled() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
isAutoClean() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
isBackedByArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
isBackedByArray() - Method in class org.apache.accumulo.core.data.ByteSequence
 
isClassProperty(String) - Static method in enum org.apache.accumulo.core.conf.Property
 
isClientAuth() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
isClosed() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
isClosed() - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
 
isClosed() - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
Returns true if this batch writer has been closed.
isConnectorInfoSet(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Determines if the connector has been configured.
isConnectorInfoSet(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Determines if the connector has been configured.
isConnectorInfoSet(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Determines if the connector has been configured.
isConnectorInfoSet(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Determines if the connector has been configured.
isConnectorInfoSet(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Determines if the connector info has already been set for this instance.
isConnectorInfoSet(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
isCurrent() - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
 
isDebugEnabled() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
isDebuggingEnabled() - Static method in class org.apache.accumulo.core.util.shell.Shell
 
isDefaultLocalityGroup - Variable in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
 
isDeleted() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
isDeleted() - Method in class org.apache.accumulo.core.data.Key
 
isDeprecated() - Method in enum org.apache.accumulo.core.conf.Property
 
isDestroyed() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
isDestroyed() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
isDestroyed() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
isDoTimestamps() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
isEmpty() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
isEmpty() - Method in class org.apache.accumulo.core.constraints.Violations
 
isEmpty() - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
 
isEmpty() - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
isEmpty() - Method in class org.apache.accumulo.core.security.Authorizations
Checks if this collection of authorizations is empty.
isEmpty() - Method in class org.apache.accumulo.core.util.BinaryTree
 
isEndKeyInclusive() - Method in class org.apache.accumulo.core.data.Range
 
isExperimental() - Method in enum org.apache.accumulo.core.conf.Property
 
isFake() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
isFixedZooPropertyKey(Property) - Static method in enum org.apache.accumulo.core.conf.Property
 
isForce() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
isFullMajorCompaction() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
isHadoopCredentialProviderAvailable() - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
Determine if we can load the necessary CredentialProvider classes.
isHasTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
isHdfsZooInstance() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
isHelpEnabled() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
isIndexable() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
An indexable block supports seeking, getting a position, and associating an arbitrary index with the block
isIndexable() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
 
isIndexable() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
isInfiniteStartKey() - Method in class org.apache.accumulo.core.data.Range
 
isInfiniteStartKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
isInfiniteStopKey() - Method in class org.apache.accumulo.core.data.Range
 
isInfiniteStopKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
isIsolated(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Determines whether a configuration has isolation enabled.
isIsolated(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Determines whether a configuration has isolation enabled.
isIsolated(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Determines whether a configuration has isolation enabled.
isIsolated(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
isIsolated() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
isIsolatedScan() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
isKeyStoreSet() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
isLockHeld(String, String) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletServerLockChecker
 
isLockHeld(String, String) - Method in class org.apache.accumulo.core.client.impl.ZookeeperLockChecker
 
isMasking() - Method in class org.apache.accumulo.core.util.shell.Shell
 
isMeta() - Method in class org.apache.accumulo.core.data.KeyExtent
 
isMockInstance() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
isMore() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
isMore() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
isOffline() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
isOfflineScan(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Determines whether a configuration has the offline table scan feature enabled.
isOfflineScan(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Determines whether a configuration has the offline table scan feature enabled.
isOfflineScan() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Determines whether a configuration has the offline table scan feature enabled.
isOfflineScan(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Determines whether a configuration has the offline table scan feature enabled.
isOfflineScan(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
isolated - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
IsolatedScanner - Class in org.apache.accumulo.core.client
A scanner that presents a row isolated view of an accumulo table.
IsolatedScanner(Scanner) - Constructor for class org.apache.accumulo.core.client.IsolatedScanner
 
IsolatedScanner(Scanner, IsolatedScanner.RowBufferFactory) - Constructor for class org.apache.accumulo.core.client.IsolatedScanner
 
IsolatedScanner.MemoryRowBuffer - Class in org.apache.accumulo.core.client
 
IsolatedScanner.MemoryRowBuffer() - Constructor for class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
 
IsolatedScanner.MemoryRowBufferFactory - Class in org.apache.accumulo.core.client
 
IsolatedScanner.MemoryRowBufferFactory() - Constructor for class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBufferFactory
 
IsolationException - Exception in org.apache.accumulo.core.client.impl
 
IsolationException() - Constructor for exception org.apache.accumulo.core.client.impl.IsolationException
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeLocalUserPassword
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ping
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.success
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.throwsError
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.fails
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.success
 
isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.throwsError
 
isOneway() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
isOneway() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.beginFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.waitForFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.beginFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.executeFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.finishFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.waitForFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeNamespaceProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeSystemProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeTableProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportSplitExtent
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportTabletStatus
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setMasterGoalState
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setNamespaceProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setSystemProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setTableProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdown
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdownTabletServer
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForFlush
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getMasterStats
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.initiateFlush
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeNamespaceProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeSystemProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeTableProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportSplitExtent
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportTabletStatus
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setMasterGoalState
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setNamespaceProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setSystemProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setTableProperty
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdown
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdownTabletServer
 
isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForFlush
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveScans
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
 
isPartNextKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
isPreviousExtent(KeyExtent) - Method in class org.apache.accumulo.core.data.KeyExtent
 
isRootTablet() - Method in class org.apache.accumulo.core.data.KeyExtent
 
isSave() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
isSensitive() - Method in enum org.apache.accumulo.core.conf.Property
 
isSensitive(String) - Static method in enum org.apache.accumulo.core.conf.Property
 
isSet(ClientService.authenticate_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.authenticate_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.authenticateUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.authenticateUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.bulkImportFiles_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.bulkImportFiles_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.changeAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.changeAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.changeLocalUserPassword_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.changeLocalUserPassword_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.checkClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.checkClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.checkNamespaceClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.checkNamespaceClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.checkTableClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.checkTableClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.createLocalUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.createLocalUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.dropLocalUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.dropLocalUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getDiskUsage_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getDiskUsage_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getInstanceId_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getInstanceId_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getNamespaceConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getNamespaceConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getRootTabletLocation_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getRootTabletLocation_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getTableConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getTableConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getUserAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getUserAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getZooKeepers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getZooKeepers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.grantNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.grantNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.grantSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.grantSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.grantTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.grantTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.hasNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.hasNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.hasSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.hasSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.hasTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.hasTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.isActive_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.isActive_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.listLocalUsers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.listLocalUsers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.ping_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.ping_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.revokeNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.revokeNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.revokeSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.revokeSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.revokeTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.revokeTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TDiskUsage._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftSecurityException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftTableOperationException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftTest.fails_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftTest.fails_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftTest.success_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftTest.success_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftTest.throwsError_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftTest.throwsError_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InitialMultiScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InitialScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(IterInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MapFileInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MultiScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCMResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TColumn._Fields) - Method in class org.apache.accumulo.core.data.thrift.TColumn
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCondition._Fields) - Method in class org.apache.accumulo.core.data.thrift.TCondition
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TConditionalMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TConditionalSession._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TConstraintViolationSummary._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TKey._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKey
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TKeyExtent._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TKeyValue._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TMutation
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRange._Fields) - Method in class org.apache.accumulo.core.data.thrift.TRange
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UpdateErrors._Fields) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GcCycleStats._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GCMonitorService.getStatus_args._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GCMonitorService.getStatus_result._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GCStatus._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Compacting._Fields) - Method in class org.apache.accumulo.core.master.thrift.Compacting
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DeadServer._Fields) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.beginFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.beginFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.executeFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.executeFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.finishFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.finishFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.waitForFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.waitForFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.getMasterStats_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.getMasterStats_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.initiateFlush_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.initiateFlush_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.removeNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.removeNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.removeSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.removeSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.removeTableProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.removeTableProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.reportSplitExtent_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.reportTabletStatus_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.setMasterGoalState_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.setMasterGoalState_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.setNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.setNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.setSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.setSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.setTableProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.setTableProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.shutdown_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.shutdown_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.shutdownTabletServer_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.shutdownTabletServer_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.waitForFlush_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterClientService.waitForFlush_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MasterMonitorInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RecoveryException._Fields) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RecoveryStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TableInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletSplit._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCredentials._Fields) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActiveCompaction._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActiveScan._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ConstraintViolationException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(IteratorConfig._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(NoSuchScanIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(NotServingTabletException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.applyUpdates_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.bulkImport_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.bulkImport_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.chop_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.closeConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.closeMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.closeMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.closeScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.closeUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.closeUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.compact_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.conditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.conditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.continueMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.continueMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.continueScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.continueScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.fastHalt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.flush_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.flushTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getActiveScans_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getActiveScans_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getHistoricalStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getHistoricalStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getTabletServerStatus_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getTabletServerStatus_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getTabletStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.getTabletStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.halt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.halt_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.invalidateConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.invalidateConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.loadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.removeLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.splitTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.splitTablet_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.startConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.startConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.startMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.startMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.startScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.startScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.startUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.startUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.unloadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.update_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletClientService.update_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TIteratorSetting._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TooManyFilesException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSetAfterPart(Key, PartialKey) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates whether or not any part of key excluding part is set.
isSetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field age is set (has been assigned a value) and false otherwise
isSetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field age is set (has been assigned a value) and false otherwise
isSetArguments() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Returns true if field arguments is set (has been assigned a value) and false otherwise
isSetAuthorizationFailures() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
Returns true if field authorizationFailures is set (has been assigned a value) and false otherwise
isSetAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
Returns true if field authorizations is set (has been assigned a value) and false otherwise
isSetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field authorizations is set (has been assigned a value) and false otherwise
isSetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
Returns true if field authorizations is set (has been assigned a value) and false otherwise
isSetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field authorizations is set (has been assigned a value) and false otherwise
isSetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field authorizations is set (has been assigned a value) and false otherwise
isSetAutoClean() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Returns true if field autoClean is set (has been assigned a value) and false otherwise
isSetBadTServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field badTServers is set (has been assigned a value) and false otherwise
isSetBatch() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field batch is set (has been assigned a value) and false otherwise
isSetBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field batchSize is set (has been assigned a value) and false otherwise
isSetCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field candidates is set (has been assigned a value) and false otherwise
isSetCf() - Method in class org.apache.accumulo.core.data.thrift.TCondition
Returns true if field cf is set (has been assigned a value) and false otherwise
isSetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
Returns true if field className is set (has been assigned a value) and false otherwise
isSetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
Returns true if field className is set (has been assigned a value) and false otherwise
isSetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
Returns true if field className is set (has been assigned a value) and false otherwise
isSetClassName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
Returns true if field className is set (has been assigned a value) and false otherwise
isSetClient() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field client is set (has been assigned a value) and false otherwise
isSetCmid() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
Returns true if field cmid is set (has been assigned a value) and false otherwise
isSetCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
Returns true if field code is set (has been assigned a value) and false otherwise
isSetColFamily() - Method in class org.apache.accumulo.core.data.thrift.TKey
Returns true if field colFamily is set (has been assigned a value) and false otherwise
isSetColQualifier() - Method in class org.apache.accumulo.core.data.thrift.TKey
Returns true if field colQualifier is set (has been assigned a value) and false otherwise
isSetColumnFamily() - Method in class org.apache.accumulo.core.data.thrift.TColumn
Returns true if field columnFamily is set (has been assigned a value) and false otherwise
isSetColumnQualifier() - Method in class org.apache.accumulo.core.data.thrift.TColumn
Returns true if field columnQualifier is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field columns is set (has been assigned a value) and false otherwise
isSetColumnVisibility() - Method in class org.apache.accumulo.core.data.thrift.TColumn
Returns true if field columnVisibility is set (has been assigned a value) and false otherwise
isSetColVisibility() - Method in class org.apache.accumulo.core.data.thrift.TKey
Returns true if field colVisibility is set (has been assigned a value) and false otherwise
isSetConditions() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
Returns true if field conditions is set (has been assigned a value) and false otherwise
isSetConstrainClass() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
Returns true if field constrainClass is set (has been assigned a value) and false otherwise
isSetCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field count is set (has been assigned a value) and false otherwise
isSetCq() - Method in class org.apache.accumulo.core.data.thrift.TCondition
Returns true if field cq is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
Returns true if field current is set (has been assigned a value) and false otherwise
isSetCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
Returns true if field currentLog is set (has been assigned a value) and false otherwise
isSetCv() - Method in class org.apache.accumulo.core.data.thrift.TCondition
Returns true if field cv is set (has been assigned a value) and false otherwise
isSetCve() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
Returns true if field cve is set (has been assigned a value) and false otherwise
isSetData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
Returns true if field data is set (has been assigned a value) and false otherwise
isSetDataCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field dataCacheHits is set (has been assigned a value) and false otherwise
isSetDataCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field dataCacheRequest is set (has been assigned a value) and false otherwise
isSetDeadTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field deadTabletServers is set (has been assigned a value) and false otherwise
isSetDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field deleted is set (has been assigned a value) and false otherwise
isSetDescription() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
Returns true if field description is set (has been assigned a value) and false otherwise
isSetElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field elapsed is set (has been assigned a value) and false otherwise
isSetEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
Returns true if field endRow is set (has been assigned a value) and false otherwise
isSetEndRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Returns true if field endRow is set (has been assigned a value) and false otherwise
isSetEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Returns true if field endRow is set (has been assigned a value) and false otherwise
isSetEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Returns true if field endRow is set (has been assigned a value) and false otherwise
isSetEntries() - Method in class org.apache.accumulo.core.data.thrift.TMutation
Returns true if field entries is set (has been assigned a value) and false otherwise
isSetEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field entriesRead is set (has been assigned a value) and false otherwise
isSetEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field entriesWritten is set (has been assigned a value) and false otherwise
isSetErrorDir() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Returns true if field errorDir is set (has been assigned a value) and false otherwise
isSetErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field errors is set (has been assigned a value) and false otherwise
isSetEstimatedSize() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
Returns true if field estimatedSize is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetFail() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field fail is set (has been assigned a value) and false otherwise
isSetFailedExtents() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
Returns true if field failedExtents is set (has been assigned a value) and false otherwise
isSetFailures() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field failures is set (has been assigned a value) and false otherwise
isSetFilenames() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
Returns true if field filenames is set (has been assigned a value) and false otherwise
isSetFiles() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Returns true if field files is set (has been assigned a value) and false otherwise
isSetFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Returns true if field files is set (has been assigned a value) and false otherwise
isSetFinished() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field finished is set (has been assigned a value) and false otherwise
isSetFlushID() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Returns true if field flushID is set (has been assigned a value) and false otherwise
isSetForce() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
Returns true if field force is set (has been assigned a value) and false otherwise
isSetFullScans() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field fullScans is set (has been assigned a value) and false otherwise
isSetGoalState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field goalState is set (has been assigned a value) and false otherwise
isSetHasTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TCondition
Returns true if field hasTimestamp is set (has been assigned a value) and false otherwise
isSetHoldTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field holdTime is set (has been assigned a value) and false otherwise
isSetId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
Returns true if field id is set (has been assigned a value) and false otherwise
isSetIdleTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field idleTime is set (has been assigned a value) and false otherwise
isSetIndexCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field indexCacheHits is set (has been assigned a value) and false otherwise
isSetIndexCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field indexCacheRequest is set (has been assigned a value) and false otherwise
isSetInfiniteStartKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
Returns true if field infiniteStartKey is set (has been assigned a value) and false otherwise
isSetInfiniteStopKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
Returns true if field infiniteStopKey is set (has been assigned a value) and false otherwise
isSetIngestByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field ingestByteRate is set (has been assigned a value) and false otherwise
isSetIngestRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field ingestRate is set (has been assigned a value) and false otherwise
isSetIngestRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field ingestRate is set (has been assigned a value) and false otherwise
isSetInputFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field inputFiles is set (has been assigned a value) and false otherwise
isSetInstanceId() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
Returns true if field instanceId is set (has been assigned a value) and false otherwise
isSetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
Returns true if field interfaceMatch is set (has been assigned a value) and false otherwise
isSetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
Returns true if field interfaceMatch is set (has been assigned a value) and false otherwise
isSetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
Returns true if field interfaceMatch is set (has been assigned a value) and false otherwise
isSetInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field inUse is set (has been assigned a value) and false otherwise
isSetIsolated() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field isolated is set (has been assigned a value) and false otherwise
isSetIteratorClass() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
Returns true if field iteratorClass is set (has been assigned a value) and false otherwise
isSetIterators() - Method in class org.apache.accumulo.core.data.thrift.TCondition
Returns true if field iterators is set (has been assigned a value) and false otherwise
isSetIterators() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
Returns true if field iterators is set (has been assigned a value) and false otherwise
isSetIterName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
Returns true if field iterName is set (has been assigned a value) and false otherwise
isSetKey() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
Returns true if field key is set (has been assigned a value) and false otherwise
isSetKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
Returns true if field keyExtent is set (has been assigned a value) and false otherwise
isSetKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
Returns true if field keyExtent is set (has been assigned a value) and false otherwise
isSetLast() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
Returns true if field last is set (has been assigned a value) and false otherwise
isSetLastContact() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field lastContact is set (has been assigned a value) and false otherwise
isSetLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
Returns true if field lastLog is set (has been assigned a value) and false otherwise
isSetLastStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
Returns true if field lastStatus is set (has been assigned a value) and false otherwise
isSetLocalityGroup() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field localityGroup is set (has been assigned a value) and false otherwise
isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLogSorts() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field logSorts is set (has been assigned a value) and false otherwise
isSetLookups() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field lookups is set (has been assigned a value) and false otherwise
isSetMajors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field majors is set (has been assigned a value) and false otherwise
isSetMajors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field majors is set (has been assigned a value) and false otherwise
isSetMaxLoops() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Returns true if field maxLoops is set (has been assigned a value) and false otherwise
isSetMinors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field minors is set (has been assigned a value) and false otherwise
isSetMinors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field minors is set (has been assigned a value) and false otherwise
isSetMore() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field more is set (has been assigned a value) and false otherwise
isSetMore() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
Returns true if field more is set (has been assigned a value) and false otherwise
isSetMutation() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
Returns true if field mutation is set (has been assigned a value) and false otherwise
isSetMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
Returns true if field mutation is set (has been assigned a value) and false otherwise
isSetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
Returns true if field mutations is set (has been assigned a value) and false otherwise
isSetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
Returns true if field mutations is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
Returns true if field name is set (has been assigned a value) and false otherwise
isSetNamespaceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
Returns true if field namespaceId is set (has been assigned a value) and false otherwise
isSetNewTablets() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
Returns true if field newTablets is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
Returns true if field nssi is set (has been assigned a value) and false otherwise
isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
Returns true if field nssi is set (has been assigned a value) and false otherwise
isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
Returns true if field nssi is set (has been assigned a value) and false otherwise
isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
Returns true if field nssi is set (has been assigned a value) and false otherwise
isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
Returns true if field nssi is set (has been assigned a value) and false otherwise
isSetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
Returns true if field nste is set (has been assigned a value) and false otherwise
isSetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
Returns true if field nste is set (has been assigned a value) and false otherwise
isSetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
Returns true if field nste is set (has been assigned a value) and false otherwise
isSetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
Returns true if field nste is set (has been assigned a value) and false otherwise
isSetNum() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field num is set (has been assigned a value) and false otherwise
isSetNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
Returns true if field numberOfViolatingMutations is set (has been assigned a value) and false otherwise
isSetNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field numEntries is set (has been assigned a value) and false otherwise
isSetOldTablet() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
Returns true if field oldTablet is set (has been assigned a value) and false otherwise
isSetOnlineTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field onlineTablets is set (has been assigned a value) and false otherwise
isSetOp() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
Returns true if field op is set (has been assigned a value) and false otherwise
isSetOp() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Returns true if field op is set (has been assigned a value) and false otherwise
isSetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Returns true if field opid is set (has been assigned a value) and false otherwise
isSetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
Returns true if field opid is set (has been assigned a value) and false otherwise
isSetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
Returns true if field opid is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOsLoad() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field osLoad is set (has been assigned a value) and false otherwise
isSetOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field outputFile is set (has been assigned a value) and false otherwise
isSetPartNextKey() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field partNextKey is set (has been assigned a value) and false otherwise
isSetPartNextKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field partNextKeyInclusive is set (has been assigned a value) and false otherwise
isSetPartScan() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field partScan is set (has been assigned a value) and false otherwise
isSetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
Returns true if field password is set (has been assigned a value) and false otherwise
isSetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
Returns true if field password is set (has been assigned a value) and false otherwise
isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
Returns true if field permission is set (has been assigned a value) and false otherwise
isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
Returns true if field permission is set (has been assigned a value) and false otherwise
isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Returns true if field permission is set (has been assigned a value) and false otherwise
isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
Returns true if field permission is set (has been assigned a value) and false otherwise
isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
Returns true if field permission is set (has been assigned a value) and false otherwise
isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Returns true if field permission is set (has been assigned a value) and false otherwise
isSetPrevEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
Returns true if field prevEndRow is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPrincipal() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
Returns true if field principal is set (has been assigned a value) and false otherwise
isSetPriority() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
Returns true if field priority is set (has been assigned a value) and false otherwise
isSetPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
Returns true if field priority is set (has been assigned a value) and false otherwise
isSetProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field progress is set (has been assigned a value) and false otherwise
isSetProperties() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
Returns true if field properties is set (has been assigned a value) and false otherwise
isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
Returns true if field property is set (has been assigned a value) and false otherwise
isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
Returns true if field property is set (has been assigned a value) and false otherwise
isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
Returns true if field property is set (has been assigned a value) and false otherwise
isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
Returns true if field property is set (has been assigned a value) and false otherwise
isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
Returns true if field property is set (has been assigned a value) and false otherwise
isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
Returns true if field property is set (has been assigned a value) and false otherwise
isSetQueryByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field queryByteRate is set (has been assigned a value) and false otherwise
isSetQueryRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field queryRate is set (has been assigned a value) and false otherwise
isSetQueryRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field queryRate is set (has been assigned a value) and false otherwise
isSetQueued() - Method in class org.apache.accumulo.core.master.thrift.Compacting
Returns true if field queued is set (has been assigned a value) and false otherwise
isSetQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field queueSumDev is set (has been assigned a value) and false otherwise
isSetQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field queueTime is set (has been assigned a value) and false otherwise
isSetRange() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field range is set (has been assigned a value) and false otherwise
isSetReadaheadThreshold() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field readaheadThreshold is set (has been assigned a value) and false otherwise
isSetReason() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetRecs() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field recs is set (has been assigned a value) and false otherwise
isSetRecsInMemory() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field recsInMemory is set (has been assigned a value) and false otherwise
isSetResult() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
Returns true if field result is set (has been assigned a value) and false otherwise
isSetResult() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
Returns true if field result is set (has been assigned a value) and false otherwise
isSetResults() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field results is set (has been assigned a value) and false otherwise
isSetResults() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
Returns true if field results is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.accumulo.core.data.thrift.TKey
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRow() - Method in class org.apache.accumulo.core.data.thrift.TMutation
Returns true if field row is set (has been assigned a value) and false otherwise
isSetRunning() - Method in class org.apache.accumulo.core.master.thrift.Compacting
Returns true if field running is set (has been assigned a value) and false otherwise
isSetRuntime() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field runtime is set (has been assigned a value) and false otherwise
isSetSave() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
Returns true if field save is set (has been assigned a value) and false otherwise
isSetScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
Returns true if field scanID is set (has been assigned a value) and false otherwise
isSetScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
Returns true if field scanID is set (has been assigned a value) and false otherwise
isSetScanId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field scanId is set (has been assigned a value) and false otherwise
isSetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
Returns true if field scanID is set (has been assigned a value) and false otherwise
isSetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
Returns true if field scanID is set (has been assigned a value) and false otherwise
isSetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
Returns true if field scanID is set (has been assigned a value) and false otherwise
isSetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
Returns true if field scanID is set (has been assigned a value) and false otherwise
isSetScanRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field scanRate is set (has been assigned a value) and false otherwise
isSetScans() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field scans is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetServer() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
Returns true if field server is set (has been assigned a value) and false otherwise
isSetServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
Returns true if field serverName is set (has been assigned a value) and false otherwise
isSetServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
Returns true if field serverName is set (has been assigned a value) and false otherwise
isSetServersShuttingDown() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field serversShuttingDown is set (has been assigned a value) and false otherwise
isSetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
Returns true if field sessID is set (has been assigned a value) and false otherwise
isSetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
Returns true if field sessID is set (has been assigned a value) and false otherwise
isSetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
Returns true if field sessID is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSetTime() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Returns true if field setTime is set (has been assigned a value) and false otherwise
isSetSetTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Returns true if field setTime is set (has been assigned a value) and false otherwise
isSetSplit() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
Returns true if field split is set (has been assigned a value) and false otherwise
isSetSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field splitCreationTime is set (has been assigned a value) and false otherwise
isSetSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
Returns true if field splitPoint is set (has been assigned a value) and false otherwise
isSetSplits() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field splits is set (has been assigned a value) and false otherwise
isSetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field ssiList is set (has been assigned a value) and false otherwise
isSetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field ssiList is set (has been assigned a value) and false otherwise
isSetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field ssiList is set (has been assigned a value) and false otherwise
isSetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field ssiList is set (has been assigned a value) and false otherwise
isSetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field ssio is set (has been assigned a value) and false otherwise
isSetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field ssio is set (has been assigned a value) and false otherwise
isSetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field ssio is set (has been assigned a value) and false otherwise
isSetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field ssio is set (has been assigned a value) and false otherwise
isSetStart() - Method in class org.apache.accumulo.core.data.thrift.TRange
Returns true if field start is set (has been assigned a value) and false otherwise
isSetStarted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field started is set (has been assigned a value) and false otherwise
isSetStartKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
Returns true if field startKeyInclusive is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field state is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStop() - Method in class org.apache.accumulo.core.data.thrift.TRange
Returns true if field stop is set (has been assigned a value) and false otherwise
isSetStopKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
Returns true if field stopKeyInclusive is set (has been assigned a value) and false otherwise
isSetStopTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
Returns true if field stopTabletServers is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field sumDev is set (has been assigned a value) and false otherwise
isSetSymbols() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
Returns true if field symbols is set (has been assigned a value) and false otherwise
isSetSysPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
Returns true if field sysPerm is set (has been assigned a value) and false otherwise
isSetTable() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
Returns true if field table is set (has been assigned a value) and false otherwise
isSetTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Returns true if field tableId is set (has been assigned a value) and false otherwise
isSetTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
Returns true if field tableId is set (has been assigned a value) and false otherwise
isSetTableId() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
Returns true if field tableId is set (has been assigned a value) and false otherwise
isSetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field tableId is set (has been assigned a value) and false otherwise
isSetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Returns true if field tableId is set (has been assigned a value) and false otherwise
isSetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Returns true if field tableId is set (has been assigned a value) and false otherwise
isSetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
Returns true if field tableId is set (has been assigned a value) and false otherwise
isSetTableID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
Returns true if field tableID is set (has been assigned a value) and false otherwise
isSetTableMap() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field tableMap is set (has been assigned a value) and false otherwise
isSetTableMap() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field tableMap is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTables() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
Returns true if field tables is set (has been assigned a value) and false otherwise
isSetTables() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
Returns true if field tables is set (has been assigned a value) and false otherwise
isSetTablet() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
Returns true if field tablet is set (has been assigned a value) and false otherwise
isSetTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field tablets is set (has been assigned a value) and false otherwise
isSetTabletServer() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
Returns true if field tabletServer is set (has been assigned a value) and false otherwise
isSetTblNspcPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
Returns true if field tblNspcPerm is set (has been assigned a value) and false otherwise
isSetTblPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Returns true if field tblPerm is set (has been assigned a value) and false otherwise
isSetTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Returns true if field tid is set (has been assigned a value) and false otherwise
isSetTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
Returns true if field tid is set (has been assigned a value) and false otherwise
isSetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Returns true if field tid is set (has been assigned a value) and false otherwise
isSetTime() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
isSetTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
isSetTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TKey
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
Returns true if field tmfe is set (has been assigned a value) and false otherwise
isSetTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
Returns true if field tmfe is set (has been assigned a value) and false otherwise
isSetToAuth() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
Returns true if field toAuth is set (has been assigned a value) and false otherwise
isSetToe() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
Returns true if field toe is set (has been assigned a value) and false otherwise
isSetToken() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
Returns true if field token is set (has been assigned a value) and false otherwise
isSetTokenClassName() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
Returns true if field tokenClassName is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTs() - Method in class org.apache.accumulo.core.data.thrift.TCondition
Returns true if field ts is set (has been assigned a value) and false otherwise
isSetTServerInfo() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field tServerInfo is set (has been assigned a value) and false otherwise
isSetTserverLock() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
Returns true if field tserverLock is set (has been assigned a value) and false otherwise
isSetTtl() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
Returns true if field ttl is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field type is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field type is set (has been assigned a value) and false otherwise
isSetUnassignedTablets() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field unassignedTablets is set (has been assigned a value) and false otherwise
isSetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
Returns true if field updateID is set (has been assigned a value) and false otherwise
isSetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
Returns true if field updateID is set (has been assigned a value) and false otherwise
isSetUsage() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
Returns true if field usage is set (has been assigned a value) and false otherwise
isSetUser() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
Returns true if field user is set (has been assigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field user is set (has been assigned a value) and false otherwise
isSetVal() - Method in class org.apache.accumulo.core.data.thrift.TCondition
Returns true if field val is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.accumulo.core.data.thrift.TMutation
Returns true if field values is set (has been assigned a value) and false otherwise
isSetViolationCode() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
Returns true if field violationCode is set (has been assigned a value) and false otherwise
isSetViolationDescription() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
Returns true if field violationDescription is set (has been assigned a value) and false otherwise
isSetViolationSummaries() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
Returns true if field violationSummaries is set (has been assigned a value) and false otherwise
isSetViolationSummaries() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
Returns true if field violationSummaries is set (has been assigned a value) and false otherwise
isSetWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Returns true if field waitForWrites is set (has been assigned a value) and false otherwise
isSetWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Returns true if field waitForWrites is set (has been assigned a value) and false otherwise
isSetWhy() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
Returns true if field why is set (has been assigned a value) and false otherwise
isSsl() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
 
isStartKeyInclusive() - Method in class org.apache.accumulo.core.data.Range
 
isStartKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
isStopKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
isStopTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
isSupported() - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
isSupportedAccumuloProperty(Property) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
The supported Accumulo properties we set in this OutputFormat, that change the behavior of the RecordWriter.
These properties correspond to the supported public static setter methods available to this class.
isSupportedAccumuloProperty(Property) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
isTabCompletion() - Method in class org.apache.accumulo.core.util.shell.Shell
 
isTabCompletionDisabled() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
isTimeSet() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
isTrustStoreSet() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
isValid(T) - Method in class org.apache.accumulo.core.util.ArgumentChecker.Validator
 
isValidEncoding(String) - Static method in class org.apache.accumulo.core.iterators.conf.ColumnSet
 
isValidFormat(String) - Method in enum org.apache.accumulo.core.conf.PropertyType
 
isValidPath(Path) - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
 
isValidPath(Path) - Method in interface org.apache.accumulo.core.volume.Volume
Determine if the Path is valid on this Volume.
isValidPath(Path) - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
isValidPropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
 
isValidTablePropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
 
isValidZooPropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
 
isVerbose() - Method in class org.apache.accumulo.core.util.shell.Shell
 
isWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
isWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
iter - Variable in class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
iter - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
IterationInterruptedException - Exception in org.apache.accumulo.core.iterators
 
IterationInterruptedException() - Constructor for exception org.apache.accumulo.core.iterators.IterationInterruptedException
 
IterationInterruptedException(String) - Constructor for exception org.apache.accumulo.core.iterators.IterationInterruptedException
 
iterator() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
iterator() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
iterator() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
Returns an iterator over an accumulo table.
iterator() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
iterator() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
 
iterator() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
iterator() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
 
iterator() - Method in class org.apache.accumulo.core.client.mock.MockBatchScanner
 
iterator() - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
iterator() - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
iterator() - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns an iterator over an accumulo table.
iterator() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
iterator() - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
 
iterator() - Method in class org.apache.accumulo.core.security.Authorizations
 
iterator() - Method in class org.apache.accumulo.core.util.shell.commands.QuotedStringTokenizer
 
IteratorAdapter - Class in org.apache.accumulo.core.client.mock
 
IteratorAdapter(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.client.mock.IteratorAdapter
 
iteratorClass - Variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
IteratorConfig - Class in org.apache.accumulo.core.tabletserver.thrift
 
IteratorConfig() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
IteratorConfig(List<TIteratorSetting>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
IteratorConfig(IteratorConfig) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
Performs a deep copy on other.
IteratorConfig._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
IteratorEnvironment - Interface in org.apache.accumulo.core.iterators
 
iteratorProfiles - Variable in class org.apache.accumulo.core.util.shell.Shell
 
iterators - Variable in class org.apache.accumulo.core.data.thrift.TCondition
 
iterators - Variable in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
IteratorSetting - Class in org.apache.accumulo.core.client
Configure an iterator for minc, majc, and/or scan.
IteratorSetting(int, String, String) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
Constructs an iterator setting configured for the scan scope with no parameters.
IteratorSetting(int, String, String, Map<String, String>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
Constructs an iterator setting configured for the specified scopes with the specified parameters.
IteratorSetting(int, Class<? extends SortedKeyValueIterator<Key, Value>>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
Constructs an iterator setting using the given class's SimpleName for the iterator name.
IteratorSetting(int, Class<? extends SortedKeyValueIterator<Key, Value>>, Map<String, String>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
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, String, Class<? extends SortedKeyValueIterator<Key, Value>>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
Constructs an iterator setting configured for the scan scope with no parameters.
IteratorSetting(int, String, Class<? extends SortedKeyValueIterator<Key, Value>>, Map<String, String>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
Constructs an iterator setting using the provided name and the provided class's name for the scan scope with the provided parameters.
IteratorSetting(DataInput) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
 
IteratorSetting.Column - Class in org.apache.accumulo.core.client
A convenience class for passing column family and column qualifiers to iterator configuration methods.
IteratorSetting.Column(Text, Text) - Constructor for class org.apache.accumulo.core.client.IteratorSetting.Column
 
IteratorSetting.Column(Text) - Constructor for class org.apache.accumulo.core.client.IteratorSetting.Column
 
IteratorSetting.Column(String, String) - Constructor for class org.apache.accumulo.core.client.IteratorSetting.Column
 
IteratorSetting.Column(String) - Constructor for class org.apache.accumulo.core.client.IteratorSetting.Column
 
IteratorUtil - Class in org.apache.accumulo.core.iterators
 
IteratorUtil() - Constructor for class org.apache.accumulo.core.iterators.IteratorUtil
 
IteratorUtil.IteratorScope - Enum in org.apache.accumulo.core.iterators
 
IteratorUtil.IterInfoComparator - Class in org.apache.accumulo.core.iterators
 
IteratorUtil.IterInfoComparator() - Constructor for class org.apache.accumulo.core.iterators.IteratorUtil.IterInfoComparator
 
IterInfo - Class in org.apache.accumulo.core.data.thrift
 
IterInfo() - Constructor for class org.apache.accumulo.core.data.thrift.IterInfo
 
IterInfo(int, String, String) - Constructor for class org.apache.accumulo.core.data.thrift.IterInfo
 
IterInfo(IterInfo) - Constructor for class org.apache.accumulo.core.data.thrift.IterInfo
Performs a deep copy on other.
IterInfo._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
iterName - Variable in class org.apache.accumulo.core.data.thrift.IterInfo
 

J

join(Collection<String>, String) - Static method in class org.apache.accumulo.core.util.StringUtil
 

K

kDepth - Static variable in class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
 
KET - Static variable in class org.apache.accumulo.core.client.impl.Translators
 
Key - Class in org.apache.accumulo.core.data
 
Key() - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with empty row, empty column family, empty column qualifier, empty column visibility, timestamp Long.MAX_VALUE, and delete marker false.
Key(Text) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the specified row, empty column family, empty column qualifier, empty column visibility, timestamp Long.MAX_VALUE, and delete marker false.
Key(Text, long) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the specified row, empty column family, empty column qualifier, empty column visibility, the specified timestamp, and delete marker false.
Key(byte[], int, int, byte[], int, int, byte[], int, int, byte[], int, int, long) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(byte[], byte[], byte[], byte[], long) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(byte[], byte[], byte[], byte[], long, boolean) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(byte[], byte[], byte[], byte[], long, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(Text, Text) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the specified row, the specified column family, empty column qualifier, empty column visibility, timestamp Long.MAX_VALUE, and delete marker false.
Key(Text, Text, Text) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the specified row, the specified column family, the specified column qualifier, empty column visibility, timestamp Long.MAX_VALUE, and delete marker false.
Key(Text, Text, Text, Text) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the specified row, the specified column family, the specified column qualifier, the specified column visibility, timestamp Long.MAX_VALUE, and delete marker false.
Key(Text, Text, Text, long) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the specified row, the specified column family, the specified column qualifier, empty column visibility, the specified timestamp, and delete marker false.
Key(Text, Text, Text, Text, long) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the specified row, the specified column family, the specified column qualifier, the specified column visibility, the specified timestamp, and delete marker false.
Key(Text, Text, Text, ColumnVisibility, long) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the specified row, the specified column family, the specified column qualifier, the specified column visibility, the specified timestamp, and delete marker false.
Key(CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
Converts CharSequence to Text and creates a Key using Key.Key(Text).
Key(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
Converts CharSequence to Text and creates a Key using Key.Key(Text,Text).
Key(CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
Converts CharSequence to Text and creates a Key using Key.Key(Text,Text,Text).
Key(CharSequence, CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
Converts CharSequence to Text and creates a Key using Key.Key(Text,Text,Text,Text).
Key(CharSequence, CharSequence, CharSequence, long) - Constructor for class org.apache.accumulo.core.data.Key
Converts CharSequence to Text and creates a Key using Key.Key(Text,Text,Text,long).
Key(CharSequence, CharSequence, CharSequence, CharSequence, long) - Constructor for class org.apache.accumulo.core.data.Key
Converts CharSequence to Text and creates a Key using Key.Key(Text,Text,Text,Text,long).
Key(CharSequence, CharSequence, CharSequence, ColumnVisibility, long) - Constructor for class org.apache.accumulo.core.data.Key
Converts CharSequence to Text and creates a Key using Key.Key(Text,Text,Text,ColumnVisibility,long).
Key(Key) - Constructor for class org.apache.accumulo.core.data.Key
Creates a key with the same row, column family, column qualifier, column visibility, timestamp, and delete marker as the given key.
Key(TKey) - Constructor for class org.apache.accumulo.core.data.Key
 
key - Variable in class org.apache.accumulo.core.data.thrift.TKeyValue
 
KeyExtent - Class in org.apache.accumulo.core.data
 
KeyExtent() - Constructor for class org.apache.accumulo.core.data.KeyExtent
Default constructor
KeyExtent(Text, Text, Text) - Constructor for class org.apache.accumulo.core.data.KeyExtent
 
KeyExtent(KeyExtent) - Constructor for class org.apache.accumulo.core.data.KeyExtent
 
KeyExtent(TKeyExtent) - Constructor for class org.apache.accumulo.core.data.KeyExtent
 
KeyExtent(Text, Value) - Constructor for class org.apache.accumulo.core.data.KeyExtent
 
KeyExtent(Text, Text) - Constructor for class org.apache.accumulo.core.data.KeyExtent
 
keyExtent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
keyExtent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
KeyFunctor - Interface in org.apache.accumulo.core.file.keyfunctor
 
keyPos - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
KeyRangePartitioner - Class in org.apache.accumulo.core.client.mapreduce.lib.partition
Hadoop partitioner that uses ranges based on row keys, and optionally sub-bins based on hashing.
KeyRangePartitioner() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
 
keys - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
keySet() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
keySet() - Method in class org.apache.accumulo.core.util.MapCounter
 
KeyValue - Class in org.apache.accumulo.core.data
A key/value pair.
KeyValue(Key, byte[]) - Constructor for class org.apache.accumulo.core.data.KeyValue
Creates a new key/value pair.
KeyValue(Key, ByteBuffer) - Constructor for class org.apache.accumulo.core.data.KeyValue
Creates a new key/value pair.
KeyValue(Key, Value) - Constructor for class org.apache.accumulo.core.data.KeyValue
Creates a new key/value pair.

L

LargeRowFilter - Class in org.apache.accumulo.core.iterators
Deprecated.
since 1.4, replaced by LargeRowFilter
LargeRowFilter() - Constructor for class org.apache.accumulo.core.iterators.LargeRowFilter
Deprecated.
 
LargeRowFilter - Class in org.apache.accumulo.core.iterators.user
This iterator suppresses rows that exceed a specified number of columns.
LargeRowFilter() - Constructor for class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
last - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
lastContact - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
lastLog - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
lastStatus - Variable in class org.apache.accumulo.core.master.thrift.DeadServer
 
lastTabletRow - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
length - Variable in class org.apache.accumulo.core.data.ArrayByteSequence
 
length() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
length() - Method in class org.apache.accumulo.core.data.ByteSequence
 
length() - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
Lexicoder<T> - Interface in org.apache.accumulo.core.client.lexicoder
A lexicoder provides methods to convert to/from byte arrays.
list() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Retrieve a list of namespaces in Accumulo.
list() - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Retrieve a list of tables in Accumulo.
list() - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
list() - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Retrieve a list of tables in Accumulo.
list - Variable in class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
list - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
ListCompactionsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ListCompactionsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ListCompactionsCommand
 
listConstraints(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
List constraints on a namespace with their assigned numbers.
listConstraints(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
List constraints on a table with their assigned numbers.
listConstraints(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
listConstraints(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
listIterators(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Get a list of iterators for this namespace.
listIterators(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Get a list of iterators for this table.
listIterators(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
listIterators(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
ListIterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ListIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ListIterCommand
 
ListLexicoder<LT> - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder to encode/decode a Java List to/from a byte array where the concatenation of each encoded element sorts lexicographically.
ListLexicoder(Lexicoder<LT>) - Constructor for class org.apache.accumulo.core.client.lexicoder.ListLexicoder
 
listLocalUsers() - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Return a list of users in accumulo
listLocalUsers() - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
listLocalUsers(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
listLocalUsers(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
listLocalUsers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
listLocalUsers(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
ListScansCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ListScansCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ListScansCommand
 
ListShellIterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ListShellIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ListShellIterCommand
 
listSplits(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
listSplits(String, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
listSplits(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
listSplits(String, int) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
listUsers() - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Deprecated.
since 1.5.0; use SecurityOperations.listLocalUsers() or the user management functions of your configured authenticator instead.
listUsers() - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
Deprecated.
loadDefault() - Static method in class org.apache.accumulo.core.client.ClientConfiguration
Attempts to load a configuration file from the system.
loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, IteratorEnvironment) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, List<IteratorSetting>, IteratorEnvironment) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, List<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, List<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment, boolean) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
loadIterators(SortedKeyValueIterator<K, V>, Collection<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment, boolean, String) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
loadIterators(SortedKeyValueIterator<K, V>, Collection<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment, boolean, String, Map<String, Class<? extends SortedKeyValueIterator<K, V>>>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
loadTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
loadTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
loadTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
loadTablet(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
localityGroup - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
LocalityGroupIterator - Class in org.apache.accumulo.core.iterators.system
 
LocalityGroupIterator(LocalityGroupIterator.LocalityGroup[], Set<ByteSequence>) - Constructor for class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
 
LocalityGroupIterator.LocalityGroup - Class in org.apache.accumulo.core.iterators.system
 
LocalityGroupIterator.LocalityGroup(InterruptibleIterator, Map<ByteSequence, MutableLong>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
 
LocalityGroupIterator.LocalityGroup(Map<ByteSequence, MutableLong>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
 
LocalityGroupUtil - Class in org.apache.accumulo.core.util
 
LocalityGroupUtil() - Constructor for class org.apache.accumulo.core.util.LocalityGroupUtil
 
LocalityGroupUtil.LocalityGroupConfigurationError - Exception in org.apache.accumulo.core.util
 
LocalityGroupUtil.Partitioner - Class in org.apache.accumulo.core.util
 
LocalityGroupUtil.Partitioner(Map<ByteSequence, MutableLong>[]) - Constructor for class org.apache.accumulo.core.util.LocalityGroupUtil.Partitioner
 
locateTablet(Credentials, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
locateTablet(Credentials, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
 
locateTablet(Credentials, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
locateTablet(Credentials, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
 
locateTablet(Credentials, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
 
locateTablet(Text, boolean, boolean, TCredentials) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
Deprecated.
 
locationObtainer - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
LOCK_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds lock IDs to enable a sanity check to ensure that the TServer writing to the metadata tablet is not dead
log - Static variable in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
 
log - Static variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
 
log - Static variable in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
 
log - Static variable in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
 
log - Static variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
 
log - Static variable in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
log - Static variable in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
log - Static variable in class org.apache.accumulo.core.iterators.OrIterator
 
log - Static variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
log - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
log - Static variable in class org.apache.accumulo.core.util.shell.Shell
 
log - Static variable in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
LogEntry - Class in org.apache.accumulo.core.tabletserver.log
 
LogEntry() - Constructor for class org.apache.accumulo.core.tabletserver.log.LogEntry
 
LogEntry(LogEntry) - Constructor for class org.apache.accumulo.core.tabletserver.log.LogEntry
 
LoggingRunnable - Class in org.apache.accumulo.core.util
 
LoggingRunnable(Logger, Runnable) - Constructor for class org.apache.accumulo.core.util.LoggingRunnable
 
loginProps - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
logSet - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
logSorts - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
logStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
longArrayToBytes(long[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
Deprecated.
 
LongCombiner - Class in org.apache.accumulo.core.iterators
A TypedValueCombiner that translates each Value to a Long before reducing, then encodes the reduced Long back to a Value.
LongCombiner() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner
 
LongCombiner.FixedLenEncoder - Class in org.apache.accumulo.core.iterators
An Encoder that uses an 8-byte encoding for Longs.
LongCombiner.FixedLenEncoder() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
LongCombiner.StringEncoder - Class in org.apache.accumulo.core.iterators
An Encoder that uses a String representation of Longs.
LongCombiner.StringEncoder() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
 
LongCombiner.Type - Enum in org.apache.accumulo.core.iterators
 
LongCombiner.VarLenEncoder - Class in org.apache.accumulo.core.iterators
An Encoder that uses a variable-length encoding for Longs.
LongCombiner.VarLenEncoder() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
 
LongLexicoder - Class in org.apache.accumulo.core.client.lexicoder
Signed long lexicoder.
LongLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.LongLexicoder
 
LongSummation - Class in org.apache.accumulo.core.iterators.aggregation
Deprecated.
since 1.4, replaced by SummingCombiner with LongCombiner.Type.FIXEDLEN
LongSummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.LongSummation
Deprecated.
 
longToBytes(long) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
Deprecated.
 
longToBytes(long) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
Deprecated.
 
lookup(Key) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
lookupInstanceName(ZooCache, UUID) - Static method in class org.apache.accumulo.core.client.ZooKeeperInstance
Given a zooCache and instanceId, look up the instance name.
lookups - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
lookupTablet(Credentials, TabletLocator.TabletLocation, Text, Text, TabletLocator) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletLocationObtainer
 
lookupTablet(Credentials, TabletLocator.TabletLocation, Text, Text, TabletLocator) - Method in class org.apache.accumulo.core.metadata.MetadataLocationObtainer
 
lookupTablets(Credentials, String, Map<KeyExtent, List<Range>>, TabletLocator) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletLocationObtainer
 
lookupTablets(Credentials, String, Map<KeyExtent, List<Range>>, TabletLocator) - Method in class org.apache.accumulo.core.metadata.MetadataLocationObtainer
 
LOSSY - Static variable in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
lowerBound(List<? extends T>, T, Comparator<? super T>) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Lower bound binary search.
lowerBound(List<? extends Comparable<? super T>>, T) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Lower bound binary search.
LruBlockCache - Class in org.apache.accumulo.core.file.blockfile.cache
A block cache implementation that is memory-aware using HeapSize, memory-bound using an LRU eviction algorithm, and concurrent: backed by a ConcurrentHashMap and with a non-blocking eviction thread giving constant-time LruBlockCache.cacheBlock(java.lang.String, byte[], boolean) and LruBlockCache.getBlock(java.lang.String) operations.
LruBlockCache(long, long) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Default constructor.
LruBlockCache(long, long, boolean) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Constructor used for testing.
LruBlockCache(long, long, boolean, int, float, int, float, float, float, float, float) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Configurable constructor.
LruBlockCache.CacheStats - Class in org.apache.accumulo.core.file.blockfile.cache
 
LruBlockCache.CacheStats() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 

M

main(String[]) - Static method in class org.apache.accumulo.core.file.BloomFilterLayer
 
main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.PrintInfo
 
main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.CreateEmpty
 
main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.PrintInfo
 
main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.SplitLarge
 
main(String[]) - Static method in class org.apache.accumulo.core.trace.TraceDump
 
main(String[]) - Static method in class org.apache.accumulo.core.util.CreateToken
 
main(String[]) - Static method in class org.apache.accumulo.core.util.Merge
 
main(String[]) - Static method in class org.apache.accumulo.core.util.shell.Shell
 
majors - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
majors - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
makeCommands(String...) - Static method in class org.apache.accumulo.core.client.mock.MockShell
Convenience method to create the byte-array to hand to the console
MAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for entry in map
MapCounter<KT> - Class in org.apache.accumulo.core.util
 
MapCounter() - Constructor for class org.apache.accumulo.core.util.MapCounter
 
MAPFILE_EXTENSION - Static variable in class org.apache.accumulo.core.Constants
 
MapFileInfo - Class in org.apache.accumulo.core.data.thrift
 
MapFileInfo() - Constructor for class org.apache.accumulo.core.data.thrift.MapFileInfo
 
MapFileInfo(long) - Constructor for class org.apache.accumulo.core.data.thrift.MapFileInfo
 
MapFileInfo(MapFileInfo) - Constructor for class org.apache.accumulo.core.data.thrift.MapFileInfo
Performs a deep copy on other.
MapFileInfo._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MapFileIterator - Class in org.apache.accumulo.core.iterators.system
 
MapFileIterator(AccumuloConfiguration, FileSystem, String, Configuration) - Constructor for class org.apache.accumulo.core.iterators.system.MapFileIterator
 
MapFileOperations - Class in org.apache.accumulo.core.file.map
 
MapFileOperations() - Constructor for class org.apache.accumulo.core.file.map.MapFileOperations
 
MapFileOperations.RangeIterator - Class in org.apache.accumulo.core.file.map
 
MapFileOperations.RangeIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
MapFileUtil - Class in org.apache.accumulo.core.file.map
 
MapFileUtil() - Constructor for class org.apache.accumulo.core.file.map.MapFileUtil
 
mark(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
mark(int) - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
 
markSupported() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
markSupported() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
 
MasterClient - Class in org.apache.accumulo.core.client.impl
 
MasterClient() - Constructor for class org.apache.accumulo.core.client.impl.MasterClient
 
MasterClientService - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService
 
MasterClientService.AsyncClient - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
MasterClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.Factory
 
MasterClientService.AsyncClient.getMasterStats_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.getMasterStats_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getMasterStats_call
 
MasterClientService.AsyncClient.initiateFlush_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.initiateFlush_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.initiateFlush_call
 
MasterClientService.AsyncClient.removeNamespaceProperty_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.removeNamespaceProperty_call(TInfo, TCredentials, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeNamespaceProperty_call
 
MasterClientService.AsyncClient.removeSystemProperty_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.removeSystemProperty_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeSystemProperty_call
 
MasterClientService.AsyncClient.removeTableProperty_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.removeTableProperty_call(TInfo, TCredentials, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeTableProperty_call
 
MasterClientService.AsyncClient.reportSplitExtent_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.reportSplitExtent_call(TInfo, TCredentials, String, TabletSplit, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.reportSplitExtent_call
 
MasterClientService.AsyncClient.reportTabletStatus_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.reportTabletStatus_call(TInfo, TCredentials, String, TabletLoadState, TKeyExtent, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.reportTabletStatus_call
 
MasterClientService.AsyncClient.setMasterGoalState_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.setMasterGoalState_call(TInfo, TCredentials, MasterGoalState, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setMasterGoalState_call
 
MasterClientService.AsyncClient.setNamespaceProperty_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.setNamespaceProperty_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setNamespaceProperty_call
 
MasterClientService.AsyncClient.setSystemProperty_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.setSystemProperty_call(TInfo, TCredentials, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setSystemProperty_call
 
MasterClientService.AsyncClient.setTableProperty_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.setTableProperty_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setTableProperty_call
 
MasterClientService.AsyncClient.shutdown_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.shutdown_call(TInfo, TCredentials, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.shutdown_call
 
MasterClientService.AsyncClient.shutdownTabletServer_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.shutdownTabletServer_call(TInfo, TCredentials, String, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.shutdownTabletServer_call
 
MasterClientService.AsyncClient.waitForFlush_call - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncClient.waitForFlush_call(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.waitForFlush_call
 
MasterClientService.AsyncIface - Interface in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor
 
MasterClientService.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor
 
MasterClientService.AsyncProcessor.getMasterStats<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.getMasterStats() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
 
MasterClientService.AsyncProcessor.initiateFlush<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.initiateFlush() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
 
MasterClientService.AsyncProcessor.removeNamespaceProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.removeNamespaceProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeNamespaceProperty
 
MasterClientService.AsyncProcessor.removeSystemProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.removeSystemProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeSystemProperty
 
MasterClientService.AsyncProcessor.removeTableProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.removeTableProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeTableProperty
 
MasterClientService.AsyncProcessor.reportSplitExtent<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.reportSplitExtent() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportSplitExtent
 
MasterClientService.AsyncProcessor.reportTabletStatus<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.reportTabletStatus() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportTabletStatus
 
MasterClientService.AsyncProcessor.setMasterGoalState<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.setMasterGoalState() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setMasterGoalState
 
MasterClientService.AsyncProcessor.setNamespaceProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.setNamespaceProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setNamespaceProperty
 
MasterClientService.AsyncProcessor.setSystemProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.setSystemProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setSystemProperty
 
MasterClientService.AsyncProcessor.setTableProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.setTableProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setTableProperty
 
MasterClientService.AsyncProcessor.shutdown<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.shutdown() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdown
 
MasterClientService.AsyncProcessor.shutdownTabletServer<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.shutdownTabletServer() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdownTabletServer
 
MasterClientService.AsyncProcessor.waitForFlush<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.AsyncProcessor.waitForFlush() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForFlush
 
MasterClientService.Client - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Client(TProtocol) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
MasterClientService.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
MasterClientService.Client.Factory - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Client.Factory() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Client.Factory
 
MasterClientService.getMasterStats_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.getMasterStats_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
MasterClientService.getMasterStats_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
MasterClientService.getMasterStats_args(MasterClientService.getMasterStats_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
Performs a deep copy on other.
MasterClientService.getMasterStats_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.getMasterStats_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.getMasterStats_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
MasterClientService.getMasterStats_result(MasterMonitorInfo, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
MasterClientService.getMasterStats_result(MasterClientService.getMasterStats_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
Performs a deep copy on other.
MasterClientService.getMasterStats_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.Iface - Interface in org.apache.accumulo.core.master.thrift
 
MasterClientService.initiateFlush_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.initiateFlush_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
MasterClientService.initiateFlush_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
MasterClientService.initiateFlush_args(MasterClientService.initiateFlush_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
Performs a deep copy on other.
MasterClientService.initiateFlush_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.initiateFlush_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.initiateFlush_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
MasterClientService.initiateFlush_result(long, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
MasterClientService.initiateFlush_result(MasterClientService.initiateFlush_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
Performs a deep copy on other.
MasterClientService.initiateFlush_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.Processor<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor(I) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor
 
MasterClientService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor
 
MasterClientService.Processor.getMasterStats<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.getMasterStats() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getMasterStats
 
MasterClientService.Processor.initiateFlush<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.initiateFlush() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.initiateFlush
 
MasterClientService.Processor.removeNamespaceProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.removeNamespaceProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeNamespaceProperty
 
MasterClientService.Processor.removeSystemProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.removeSystemProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeSystemProperty
 
MasterClientService.Processor.removeTableProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.removeTableProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeTableProperty
 
MasterClientService.Processor.reportSplitExtent<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.reportSplitExtent() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportSplitExtent
 
MasterClientService.Processor.reportTabletStatus<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.reportTabletStatus() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportTabletStatus
 
MasterClientService.Processor.setMasterGoalState<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.setMasterGoalState() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setMasterGoalState
 
MasterClientService.Processor.setNamespaceProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.setNamespaceProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setNamespaceProperty
 
MasterClientService.Processor.setSystemProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.setSystemProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setSystemProperty
 
MasterClientService.Processor.setTableProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.setTableProperty() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setTableProperty
 
MasterClientService.Processor.shutdown<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.shutdown() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdown
 
MasterClientService.Processor.shutdownTabletServer<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.shutdownTabletServer() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdownTabletServer
 
MasterClientService.Processor.waitForFlush<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor.waitForFlush() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForFlush
 
MasterClientService.removeNamespaceProperty_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.removeNamespaceProperty_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
MasterClientService.removeNamespaceProperty_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
MasterClientService.removeNamespaceProperty_args(MasterClientService.removeNamespaceProperty_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
Performs a deep copy on other.
MasterClientService.removeNamespaceProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.removeNamespaceProperty_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.removeNamespaceProperty_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
MasterClientService.removeNamespaceProperty_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
MasterClientService.removeNamespaceProperty_result(MasterClientService.removeNamespaceProperty_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
Performs a deep copy on other.
MasterClientService.removeNamespaceProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.removeSystemProperty_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.removeSystemProperty_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
MasterClientService.removeSystemProperty_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
MasterClientService.removeSystemProperty_args(MasterClientService.removeSystemProperty_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
Performs a deep copy on other.
MasterClientService.removeSystemProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.removeSystemProperty_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.removeSystemProperty_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
MasterClientService.removeSystemProperty_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
MasterClientService.removeSystemProperty_result(MasterClientService.removeSystemProperty_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
Performs a deep copy on other.
MasterClientService.removeSystemProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.removeTableProperty_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.removeTableProperty_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
MasterClientService.removeTableProperty_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
MasterClientService.removeTableProperty_args(MasterClientService.removeTableProperty_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
Performs a deep copy on other.
MasterClientService.removeTableProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.removeTableProperty_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.removeTableProperty_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
MasterClientService.removeTableProperty_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
MasterClientService.removeTableProperty_result(MasterClientService.removeTableProperty_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
Performs a deep copy on other.
MasterClientService.removeTableProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.reportSplitExtent_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.reportSplitExtent_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
MasterClientService.reportSplitExtent_args(TInfo, TCredentials, String, TabletSplit) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
MasterClientService.reportSplitExtent_args(MasterClientService.reportSplitExtent_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
Performs a deep copy on other.
MasterClientService.reportSplitExtent_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.reportTabletStatus_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.reportTabletStatus_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
MasterClientService.reportTabletStatus_args(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
MasterClientService.reportTabletStatus_args(MasterClientService.reportTabletStatus_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
Performs a deep copy on other.
MasterClientService.reportTabletStatus_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.setMasterGoalState_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.setMasterGoalState_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
MasterClientService.setMasterGoalState_args(TInfo, TCredentials, MasterGoalState) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
MasterClientService.setMasterGoalState_args(MasterClientService.setMasterGoalState_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
Performs a deep copy on other.
MasterClientService.setMasterGoalState_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.setMasterGoalState_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.setMasterGoalState_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
MasterClientService.setMasterGoalState_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
MasterClientService.setMasterGoalState_result(MasterClientService.setMasterGoalState_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
Performs a deep copy on other.
MasterClientService.setMasterGoalState_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.setNamespaceProperty_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.setNamespaceProperty_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
MasterClientService.setNamespaceProperty_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
MasterClientService.setNamespaceProperty_args(MasterClientService.setNamespaceProperty_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
Performs a deep copy on other.
MasterClientService.setNamespaceProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.setNamespaceProperty_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.setNamespaceProperty_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
MasterClientService.setNamespaceProperty_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
MasterClientService.setNamespaceProperty_result(MasterClientService.setNamespaceProperty_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
Performs a deep copy on other.
MasterClientService.setNamespaceProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.setSystemProperty_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.setSystemProperty_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
MasterClientService.setSystemProperty_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
MasterClientService.setSystemProperty_args(MasterClientService.setSystemProperty_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
Performs a deep copy on other.
MasterClientService.setSystemProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.setSystemProperty_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.setSystemProperty_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
MasterClientService.setSystemProperty_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
MasterClientService.setSystemProperty_result(MasterClientService.setSystemProperty_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
Performs a deep copy on other.
MasterClientService.setSystemProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.setTableProperty_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.setTableProperty_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
MasterClientService.setTableProperty_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
MasterClientService.setTableProperty_args(MasterClientService.setTableProperty_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
Performs a deep copy on other.
MasterClientService.setTableProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.setTableProperty_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.setTableProperty_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
MasterClientService.setTableProperty_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
MasterClientService.setTableProperty_result(MasterClientService.setTableProperty_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
Performs a deep copy on other.
MasterClientService.setTableProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.shutdown_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.shutdown_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
MasterClientService.shutdown_args(TInfo, TCredentials, boolean) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
MasterClientService.shutdown_args(MasterClientService.shutdown_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
Performs a deep copy on other.
MasterClientService.shutdown_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.shutdown_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.shutdown_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
MasterClientService.shutdown_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
MasterClientService.shutdown_result(MasterClientService.shutdown_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
Performs a deep copy on other.
MasterClientService.shutdown_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.shutdownTabletServer_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.shutdownTabletServer_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
MasterClientService.shutdownTabletServer_args(TInfo, TCredentials, String, boolean) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
MasterClientService.shutdownTabletServer_args(MasterClientService.shutdownTabletServer_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
Performs a deep copy on other.
MasterClientService.shutdownTabletServer_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.shutdownTabletServer_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.shutdownTabletServer_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
MasterClientService.shutdownTabletServer_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
MasterClientService.shutdownTabletServer_result(MasterClientService.shutdownTabletServer_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
Performs a deep copy on other.
MasterClientService.shutdownTabletServer_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.waitForFlush_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.waitForFlush_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
MasterClientService.waitForFlush_args(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
MasterClientService.waitForFlush_args(MasterClientService.waitForFlush_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
Performs a deep copy on other.
MasterClientService.waitForFlush_args._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterClientService.waitForFlush_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.waitForFlush_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
MasterClientService.waitForFlush_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
MasterClientService.waitForFlush_result(MasterClientService.waitForFlush_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
Performs a deep copy on other.
MasterClientService.waitForFlush_result._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterGoalState - Enum in org.apache.accumulo.core.master.thrift
 
MasterMonitorInfo - Class in org.apache.accumulo.core.master.thrift
 
MasterMonitorInfo() - Constructor for class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
MasterMonitorInfo(Map<String, TableInfo>, List<TabletServerStatus>, Map<String, Byte>, MasterState, MasterGoalState, int, Set<String>, List<DeadServer>) - Constructor for class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
MasterMonitorInfo(MasterMonitorInfo) - Constructor for class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Performs a deep copy on other.
MasterMonitorInfo._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MasterNotRunningException - Exception in org.apache.accumulo.core.master
 
MasterNotRunningException(String) - Constructor for exception org.apache.accumulo.core.master.MasterNotRunningException
 
MasterState - Enum in org.apache.accumulo.core.master.thrift
 
MATCH_SUBSTRING - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
MAX__KEY_SIZE_EXCEEDED_VIOLATION - Static variable in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
 
MAX_BUFFER_SIZE_OPT - Static variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
MAX_CF_IN_DLG - Static variable in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
MAX_DATA_TO_PRINT - Static variable in class org.apache.accumulo.core.Constants
 
MaxCombiner - Class in org.apache.accumulo.core.iterators.user
A Combiner that interprets Values as Longs and returns the largest Long among them.
MaxCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.MaxCombiner
 
maximizeStartKeyTimeStamp(Range) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
maxLoops - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
MaxRowCommand - Class in org.apache.accumulo.core.util.shell.commands
 
MaxRowCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.MaxRowCommand
 
maxSize - Static variable in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
 
maxVersions - Variable in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
membershipTest(Key) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
membershipTest(Key) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
membershipTest(Key) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Determines whether a specified key belongs to this filter.
merge(String, Text, Text) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Merge tablets between (start, end]
merge(String, Text, Text) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
merge(String, Text, Text) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
merge(Text, Text) - Method in class org.apache.accumulo.core.client.mock.MockTable
 
Merge - Class in org.apache.accumulo.core.util
 
Merge() - Constructor for class org.apache.accumulo.core.util.Merge
 
merge(Connector, String, List<Merge.Size>, int) - Method in class org.apache.accumulo.core.util.Merge
 
Merge.MergeException - Exception in org.apache.accumulo.core.util
 
Merge.Size - Class in org.apache.accumulo.core.util
 
Merge.Size(KeyExtent, long) - Constructor for class org.apache.accumulo.core.util.Merge.Size
 
MergeCommand - Class in org.apache.accumulo.core.util.shell.commands
 
MergeCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.MergeCommand
 
mergeIteratorConfig(List<IterInfo>, Map<String, Map<String, String>>, List<IterInfo>, Map<String, Map<String, String>>, List<IterInfo>, Map<String, Map<String, String>>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
mergeMany(Connector, String, List<Merge.Size>, long, boolean, boolean) - Method in class org.apache.accumulo.core.util.Merge
 
mergeOverlapping(Collection<Range>) - Static method in class org.apache.accumulo.core.data.Range
Takes a collection on range and merges overlapping and adjacent ranges.
mergeSome(Connector, String, List<Merge.Size>, int) - Method in class org.apache.accumulo.core.util.Merge
 
mergomatic(Connector, String, Text, Text, long, boolean) - Method in class org.apache.accumulo.core.util.Merge
 
message(String, Object...) - Method in class org.apache.accumulo.core.util.Merge
 
MetaBlockAlreadyExists - Exception in org.apache.accumulo.core.file.rfile.bcfile
Exception - Meta Block with the same name already exists.
MetaBlockDoesNotExist - Exception in org.apache.accumulo.core.file.rfile.bcfile
Exception - No such Meta Block with the given name.
metaCache - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
MetadataLocationObtainer - Class in org.apache.accumulo.core.metadata
 
MetadataLocationObtainer(Instance) - Constructor for class org.apache.accumulo.core.metadata.MetadataLocationObtainer
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
metaDataMap - Static variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
metaDataMap - Static variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.InitialScan
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.IterInfo
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.ScanResult
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TCMResult
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TColumn
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TCondition
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TKey
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TKeyValue
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TMutation
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TRange
 
metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
metaDataMap - Static variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
metaDataMap - Static variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.Compacting
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.DeadServer
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
metaDataMap - Static variable in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.TabletSplit
 
metaDataMap - Static variable in class org.apache.accumulo.core.security.thrift.TCredentials
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
MetadataSchema - Class in org.apache.accumulo.core.metadata.schema
Describes the table schema used for metadata tables
MetadataSchema() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema
 
MetadataSchema.BlipSection - Class in org.apache.accumulo.core.metadata.schema
Holds bulk-load-in-progress processing flags
MetadataSchema.BlipSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
 
MetadataSchema.DeletesSection - Class in org.apache.accumulo.core.metadata.schema
Holds delete markers for potentially unused files/directories
MetadataSchema.DeletesSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
 
MetadataSchema.ReservedSection - Class in org.apache.accumulo.core.metadata.schema
Contains additional metadata in a reserved area not for tablets
MetadataSchema.ReservedSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
 
MetadataSchema.TabletsSection - Class in org.apache.accumulo.core.metadata.schema
Used for storing information about tablets
MetadataSchema.TabletsSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
MetadataSchema.TabletsSection.BulkFileColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Temporary markers that indicate a tablet loaded a bulk file
MetadataSchema.TabletsSection.BulkFileColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
MetadataSchema.TabletsSection.ChoppedColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for indicating that the files in a tablet have been trimmed to only include data for the current tablet, so that they are safe to merge
MetadataSchema.TabletsSection.ChoppedColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ChoppedColumnFamily
 
MetadataSchema.TabletsSection.ClonedColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Temporary marker that indicates a tablet was successfully cloned
MetadataSchema.TabletsSection.ClonedColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ClonedColumnFamily
 
MetadataSchema.TabletsSection.CurrentLocationColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing entries created by the TServer to indicate it has loaded a tablet that it was assigned
MetadataSchema.TabletsSection.CurrentLocationColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.CurrentLocationColumnFamily
 
MetadataSchema.TabletsSection.DataFileColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing files used by a tablet
MetadataSchema.TabletsSection.DataFileColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.DataFileColumnFamily
 
MetadataSchema.TabletsSection.FutureLocationColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing the assigned location
MetadataSchema.TabletsSection.FutureLocationColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.FutureLocationColumnFamily
 
MetadataSchema.TabletsSection.LastLocationColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing last location, as a hint for assignment
MetadataSchema.TabletsSection.LastLocationColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LastLocationColumnFamily
 
MetadataSchema.TabletsSection.LogColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing write-ahead log entries
MetadataSchema.TabletsSection.LogColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LogColumnFamily
 
MetadataSchema.TabletsSection.ScanFileColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing the set of files scanned with an isolated scanner, to prevent them from being deleted
MetadataSchema.TabletsSection.ScanFileColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ScanFileColumnFamily
 
MetadataSchema.TabletsSection.ServerColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for recording information used by the TServer
MetadataSchema.TabletsSection.ServerColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
MetadataSchema.TabletsSection.TabletColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing the tablet information needed by clients
MetadataSchema.TabletsSection.TabletColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
 
MetadataServicer - Class in org.apache.accumulo.core.metadata
Provides a consolidated API for handling table metadata
MetadataServicer() - Constructor for class org.apache.accumulo.core.metadata.MetadataServicer
 
MetadataTable - Class in org.apache.accumulo.core.metadata
 
MetadataTable() - Constructor for class org.apache.accumulo.core.metadata.MetadataTable
 
MinCombiner - Class in org.apache.accumulo.core.iterators.user
A Combiner that interprets Values as Longs and returns the smallest Long among them.
MinCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.MinCombiner
 
minimizeEndKeyTimeStamp(Range) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
minors - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
minors - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
miss() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
mock - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
MockAccumulo - Class in org.apache.accumulo.core.client.mock
 
MockBatchDeleter - Class in org.apache.accumulo.core.client.mock
BatchDeleter for a MockAccumulo instance.
MockBatchDeleter(MockAccumulo, String, Authorizations) - Constructor for class org.apache.accumulo.core.client.mock.MockBatchDeleter
Create a BatchDeleter for the specified instance on the specified table where the writer uses the specified Authorizations.
MockBatchScanner - Class in org.apache.accumulo.core.client.mock
 
MockBatchScanner(MockTable, Authorizations) - Constructor for class org.apache.accumulo.core.client.mock.MockBatchScanner
 
MockBatchWriter - Class in org.apache.accumulo.core.client.mock
 
MockConnector - Class in org.apache.accumulo.core.client.mock
 
MockInstance - Class in org.apache.accumulo.core.client.mock
Mock Accumulo provides an in memory implementation of the Accumulo client API.
MockInstance() - Constructor for class org.apache.accumulo.core.client.mock.MockInstance
 
MockInstance(String) - Constructor for class org.apache.accumulo.core.client.mock.MockInstance
 
MockInstance(String, FileSystem) - Constructor for class org.apache.accumulo.core.client.mock.MockInstance
 
MockInstanceOperations - Class in org.apache.accumulo.core.client.mock
Deprecated.
since 1.6.0; not intended for public api and you should not use it.
MockInstanceOperations(MockAccumulo) - Constructor for class org.apache.accumulo.core.client.mock.MockInstanceOperations
Deprecated.
 
MockMultiTableBatchWriter - Class in org.apache.accumulo.core.client.mock
 
MockMultiTableBatchWriter(MockAccumulo) - Constructor for class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
 
MockNamespace - Class in org.apache.accumulo.core.client.mock
 
MockNamespace() - Constructor for class org.apache.accumulo.core.client.mock.MockNamespace
 
MockScanner - Class in org.apache.accumulo.core.client.mock
 
MockScannerBase - Class in org.apache.accumulo.core.client.mock
 
MockSecurityOperations - Class in org.apache.accumulo.core.client.mock
Deprecated.
since 1.6.0; not intended for public api and you should not use it.
MockShell - Class in org.apache.accumulo.core.client.mock
An Accumulo Shell implementation that allows a developer to attach an InputStream and Writer to the Shell for testing purposes.
MockShell(InputStream, OutputStream) - Constructor for class org.apache.accumulo.core.client.mock.MockShell
 
MockShell(InputStream, Writer) - Constructor for class org.apache.accumulo.core.client.mock.MockShell
Deprecated.
since 1.6.0; use OutputStream version
MockTable - Class in org.apache.accumulo.core.client.mock
 
MockTableOperations - Class in org.apache.accumulo.core.client.mock
Deprecated.
since 1.6.0; not intended for public api and you should not use it.
MockTabletLocator - Class in org.apache.accumulo.core.client.mock.impl
 
MockTabletLocator() - Constructor for class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
 
MockTabletLocator - Class in org.apache.accumulo.core.client.mock
Deprecated.
since 1.6.0; not intended for public api and you should not use it.
MockTabletLocator() - Constructor for class org.apache.accumulo.core.client.mock.MockTabletLocator
Deprecated.
 
MockUser - Class in org.apache.accumulo.core.client.mock
 
MonitorUtil - Class in org.apache.accumulo.core.util
 
MonitorUtil() - Constructor for class org.apache.accumulo.core.util.MonitorUtil
 
more - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
more - Variable in class org.apache.accumulo.core.data.thrift.ScanResult
 
MultiIterator - Class in org.apache.accumulo.core.iterators.system
An iterator capable of iterating over other iterators in sorted order.
MultiIterator(List<SortedKeyValueIterator<Key, Value>>, Range) - Constructor for class org.apache.accumulo.core.iterators.system.MultiIterator
 
MultiIterator(List<SortedKeyValueIterator<Key, Value>>, KeyExtent) - Constructor for class org.apache.accumulo.core.iterators.system.MultiIterator
 
MultiIterator(List<SortedKeyValueIterator<Key, Value>>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.MultiIterator
 
MultiLevelIndex - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex() - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex
 
MultiLevelIndex.BufferedWriter - Class in org.apache.accumulo.core.file.rfile
this class buffers writes to the index so that chunks of index blocks are contiguous in the file instead of having index blocks sprinkled throughout the file making scans of the entire index slow.
MultiLevelIndex.BufferedWriter(MultiLevelIndex.Writer) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
 
MultiLevelIndex.IndexEntry - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex.IndexEntry(boolean) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
MultiLevelIndex.Reader - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex.Reader(BlockFileReader, int) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
MultiLevelIndex.Reader.IndexIterator - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex.Reader.IndexIterator() - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
MultiLevelIndex.Reader.IndexIterator(MultiLevelIndex.Reader.Node) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
MultiLevelIndex.Reader.Node - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex.Writer - Class in org.apache.accumulo.core.file.rfile
 
MultiScanResult - Class in org.apache.accumulo.core.data.thrift
 
MultiScanResult() - Constructor for class org.apache.accumulo.core.data.thrift.MultiScanResult
 
MultiScanResult(List<TKeyValue>, Map<TKeyExtent, List<TRange>>, List<TKeyExtent>, TKeyExtent, TKey, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.thrift.MultiScanResult
 
MultiScanResult(MultiScanResult) - Constructor for class org.apache.accumulo.core.data.thrift.MultiScanResult
Performs a deep copy on other.
MultiScanResult._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MultiTableBatchWriter - Interface in org.apache.accumulo.core.client
This class enables efficient batch writing to multiple tables.
MultiTableBatchWriterImpl - Class in org.apache.accumulo.core.client.impl
 
MultiTableBatchWriterImpl(Instance, Credentials, BatchWriterConfig) - Constructor for class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
MultiTableBatchWriterImpl(Instance, Credentials, BatchWriterConfig, long, TimeUnit) - Constructor for class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
MutableByteSequence - Class in org.apache.accumulo.core.util
 
MutableByteSequence(byte[], int, int) - Constructor for class org.apache.accumulo.core.util.MutableByteSequence
 
MutableByteSequence(ByteSequence) - Constructor for class org.apache.accumulo.core.util.MutableByteSequence
 
Mutation - Class in org.apache.accumulo.core.data
Mutation represents an action that manipulates a row in a table.
Mutation(byte[]) - Constructor for class org.apache.accumulo.core.data.Mutation
 
Mutation(byte[], int, int) - Constructor for class org.apache.accumulo.core.data.Mutation
 
Mutation(Text) - Constructor for class org.apache.accumulo.core.data.Mutation
 
Mutation(CharSequence) - Constructor for class org.apache.accumulo.core.data.Mutation
 
Mutation() - Constructor for class org.apache.accumulo.core.data.Mutation
 
Mutation(TMutation) - Constructor for class org.apache.accumulo.core.data.Mutation
 
Mutation(Mutation) - Constructor for class org.apache.accumulo.core.data.Mutation
 
mutation - Variable in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
mutation - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
Mutation.SERIALIZED_FORMAT - Enum in org.apache.accumulo.core.data
 
mutations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
mutations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
MutationsRejectedException - Exception in org.apache.accumulo.core.client
Communicate the failed mutations of a BatchWriter back to the client.
MutationsRejectedException(List<ConstraintViolationSummary>, HashMap<KeyExtent, Set<SecurityErrorCode>>, Collection<String>, int, Throwable) - Constructor for exception org.apache.accumulo.core.client.MutationsRejectedException
MutationsRejectedException(Instance, List<ConstraintViolationSummary>, HashMap<KeyExtent, Set<SecurityErrorCode>>, Collection<String>, int, Throwable) - Constructor for exception org.apache.accumulo.core.client.MutationsRejectedException
 

N

name - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
name - Variable in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
name - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
NAME - Static variable in class org.apache.accumulo.core.metadata.MetadataTable
 
NAME - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ChoppedColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ClonedColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.CurrentLocationColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.DataFileColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.FutureLocationColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LastLocationColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LogColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ScanFileColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
This needs to sort after all other column families for that tablet, because the MetadataSchema.TabletsSection.TabletColumnFamily.PREV_ROW_COLUMN sits in this and that needs to sort last because the SimpleGarbageCollector relies on this.
name - Variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
NAME_PROPERTY - Static variable in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
namedOptions - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
NamespaceExistsException - Exception in org.apache.accumulo.core.client
Thrown when the namespace specified already exists, and it was expected that it didn't
NamespaceExistsException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.NamespaceExistsException
 
NamespaceExistsException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.NamespaceExistsException
 
NamespaceExistsException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.NamespaceExistsException
 
namespaceId - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
namespaceIdMap() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Get a mapping of namespace name to internal namespace id.
namespaceIdMap() - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
NamespaceNotEmptyException - Exception in org.apache.accumulo.core.client
Thrown when the namespace specified contains tables
NamespaceNotEmptyException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
NamespaceNotEmptyException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
NamespaceNotEmptyException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
NamespaceNotFoundException - Exception in org.apache.accumulo.core.client
Thrown when the namespace specified doesn't exist when it was expected to
NamespaceNotFoundException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
NamespaceNotFoundException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
NamespaceNotFoundException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
NamespaceOperations - Interface in org.apache.accumulo.core.client.admin
Provides an API for administering namespaces All tables exist in a namespace.
namespaceOperations() - Method in class org.apache.accumulo.core.client.Connector
Retrieves a NamespaceOperations object to perform namespace functions, such as create and delete.
namespaceOperations() - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
namespaceOperations() - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
NamespaceOperationsHelper - Class in org.apache.accumulo.core.client.impl
 
NamespaceOperationsHelper() - Constructor for class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
NamespaceOperationsImpl - Class in org.apache.accumulo.core.client.impl
 
NamespaceOperationsImpl(Instance, Credentials, TableOperationsImpl) - Constructor for class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
namespaceOpt - Variable in class org.apache.accumulo.core.util.shell.commands.ConstraintCommand
 
namespaceOpt() - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
namespaceOpt(String) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
namespaceOption - Static variable in class org.apache.accumulo.core.util.shell.ShellOptions
 
NamespacePermission - Enum in org.apache.accumulo.core.security
Accumulo namespace permissions.
NamespacePermissionsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
NamespacePermissionsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.NamespacePermissionsCommand
 
Namespaces - Class in org.apache.accumulo.core.client.impl
 
Namespaces() - Constructor for class org.apache.accumulo.core.client.impl.Namespaces
 
NamespacesCommand - Class in org.apache.accumulo.core.util.shell.commands
 
NamespacesCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.NamespacesCommand
 
NamingThreadFactory - Class in org.apache.accumulo.core.util
 
NamingThreadFactory(String) - Constructor for class org.apache.accumulo.core.util.NamingThreadFactory
 
nbHash - Variable in class org.apache.accumulo.core.bloomfilter.Filter
The number of hash function to consider.
NEGATE - Static variable in class org.apache.accumulo.core.iterators.Filter
 
newBuffer() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBufferFactory
 
newColumnUpdate(byte[], byte[], byte[], boolean, long, boolean, byte[]) - Method in class org.apache.accumulo.core.data.Mutation
 
newTablets - Variable in class org.apache.accumulo.core.master.thrift.TabletSplit
 
newThread(Runnable) - Method in class org.apache.accumulo.core.util.NamingThreadFactory
 
next() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
 
next() - Method in class org.apache.accumulo.core.client.impl.ScannerIterator
 
next() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator
 
next() - Method in class org.apache.accumulo.core.client.mock.IteratorAdapter
 
next() - Method in class org.apache.accumulo.core.client.RowIterator
Fetch the next row.
next() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
next() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
next() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
next() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
next() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
next() - Method in class org.apache.accumulo.core.iterators.Combiner
 
next() - Method in class org.apache.accumulo.core.iterators.Combiner.ValueIterator
 
next() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
next() - Method in class org.apache.accumulo.core.iterators.DevNull
 
next() - Method in class org.apache.accumulo.core.iterators.Filter
 
next() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
next() - Method in class org.apache.accumulo.core.iterators.SkippingIterator
 
next() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Advances to the next K,V pair.
next() - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.CountingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.DeletingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.StatsIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
next() - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
next() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.RowFilter
 
next() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
next() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
next() - Method in class org.apache.accumulo.core.trace.TraceFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.BinaryFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.DateStringFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
next(DateFormat) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.DeleterFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
next() - Method in class org.apache.accumulo.core.util.PeekingIterator
 
nextArraySize(int) - Static method in class org.apache.accumulo.core.util.UnsynchronizedBuffer
Determines what next array size should be by rounding up to next power of two.
nextIndex() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
NO_AUTHS - Static variable in class org.apache.accumulo.core.Constants
Deprecated.
since 1.6.0; Use Authorizations.EMPTY instead
NO_FIXED_ARG_LENGTH_CHECK - Static variable in class org.apache.accumulo.core.util.shell.Shell
 
nodes - Variable in class org.apache.accumulo.core.trace.SpanTree
 
NoFlushOutputStream - Class in org.apache.accumulo.core.security.crypto
 
NoFlushOutputStream(OutputStream) - Constructor for class org.apache.accumulo.core.security.crypto.NoFlushOutputStream
 
noForce() - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
NonCachingSecretKeyEncryptionStrategy - Class in org.apache.accumulo.core.security.crypto
 
NonCachingSecretKeyEncryptionStrategy() - Constructor for class org.apache.accumulo.core.security.crypto.NonCachingSecretKeyEncryptionStrategy
 
NonConfiguredVolume - Class in org.apache.accumulo.core.volume
Volume implementation which represents a Volume for which we have a FileSystem but no base path because it is not configured via Property.INSTANCE_VOLUMES This is useful to handle volumes that have been removed from accumulo-site.xml but references to these volumes have not been updated.
NonConfiguredVolume(FileSystem) - Constructor for class org.apache.accumulo.core.volume.NonConfiguredVolume
 
normalize(ColumnVisibility.Node, byte[]) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
 
normalize(ColumnVisibility.Node, byte[], ColumnVisibility.NodeComparator) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
 
NoSuchMetaStoreException - Exception in org.apache.accumulo.core.file
 
NoSuchMetaStoreException(String, Throwable) - Constructor for exception org.apache.accumulo.core.file.NoSuchMetaStoreException
 
NoSuchMetaStoreException(String) - Constructor for exception org.apache.accumulo.core.file.NoSuchMetaStoreException
 
NoSuchScanIDException - Exception in org.apache.accumulo.core.tabletserver.thrift
 
NoSuchScanIDException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
NoSuchScanIDException(NoSuchScanIDException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
Performs a deep copy on other.
NoSuchScanIDException._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
not() - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
not() - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
not() - Method in class org.apache.accumulo.core.bloomfilter.Filter
Performs a logical NOT on this filter.
NOT_ACCUMULO - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
 
NOT_DEFAULT - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
 
NOT_ROOT - Static variable in class org.apache.accumulo.core.client.impl.Tables
 
NOT_ROOT_ID - Static variable in class org.apache.accumulo.core.client.impl.Tables
 
NOT_SYSTEM - Static variable in class org.apache.accumulo.core.client.impl.Tables
 
NoTableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
NoTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.NoTableCommand
 
notEmpty(Iterable<?>) - Static method in class org.apache.accumulo.core.util.ArgumentChecker
 
notFlag - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
notNull(Object) - Static method in class org.apache.accumulo.core.util.ArgumentChecker
 
notNull(Object, Object) - Static method in class org.apache.accumulo.core.util.ArgumentChecker
 
notNull(Object, Object, Object) - Static method in class org.apache.accumulo.core.util.ArgumentChecker
 
notNull(Object, Object, Object, Object) - Static method in class org.apache.accumulo.core.util.ArgumentChecker
 
notNull(Object[]) - Static method in class org.apache.accumulo.core.util.ArgumentChecker
 
NotServingTabletException - Exception in org.apache.accumulo.core.tabletserver.thrift
 
NotServingTabletException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
NotServingTabletException(TKeyExtent) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
NotServingTabletException(NotServingTabletException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
Performs a deep copy on other.
NotServingTabletException._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ns - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
ns - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
ns - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
ns - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
ns - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
ns - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
nssi - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
nssi - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
nssi - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
nssi - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
nssi - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
nste - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
nste - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
nste - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
nste - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
nullText - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
NullToken - Class in org.apache.accumulo.core.client.security.tokens
 
NullToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.NullToken
 
num - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.AboutCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.AddAuthsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.AddSplitsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.AuthenticateCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ClasspathCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ClearCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.CloneTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ConfigCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ConstraintCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.CreateNamespaceCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.CreateTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.CreateUserCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DebugCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteNamespaceCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteRowsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteScanIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteShellIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DropUserCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.DUCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ExecfileCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ExitCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ExportTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ExtensionCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.FateCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.GetAuthsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.GetGroupsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.GetSplitsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.GrantCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.GrepCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.HelpCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.HiddenCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.HistoryCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ImportDirectoryCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ImportTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.InsertCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ListCompactionsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ListIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ListScansCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ListShellIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.MergeCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.NamespacePermissionsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.NamespacesCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.NoTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.PasswdCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.PingCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.RenameNamespaceCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.RenameTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.RevokeCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.SetAuthsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.SetGroupsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.SetIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.ShellPluginConfigurationCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.SleepCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.SystemPermissionsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.TableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.TablePermissionsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.TablesCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.UserCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.UserPermissionsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.UsersCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.commands.WhoAmICommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
If the number of arguments is not always zero (not including those arguments handled through Options), make sure to override the Shell.Command.usage() method.
NumArraySummation - Class in org.apache.accumulo.core.iterators.aggregation
Deprecated.
NumArraySummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
Deprecated.
 
numberOfViolatingMutations - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
numberOfViolatingMutations - Variable in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
numBytes() - Method in class org.apache.accumulo.core.data.Mutation
 
numEntries - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
numKeysRead - Variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
 
numKeysRead - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
 
NumSummation - Class in org.apache.accumulo.core.iterators.aggregation
Deprecated.
since 1.4, replaced by SummingCombiner with LongCombiner.Type.VARLEN
NumSummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.NumSummation
Deprecated.
 
NumUtil - Class in org.apache.accumulo.core.util
 
NumUtil() - Constructor for class org.apache.accumulo.core.util.NumUtil
 

O

OBJECT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Object overhead is minimum 2 * reference size (8 bytes on 64-bit)
object - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
ObservableConfiguration - Class in org.apache.accumulo.core.conf
A configuration that can be observed.
ObservableConfiguration() - Constructor for class org.apache.accumulo.core.conf.ObservableConfiguration
Creates a new observable configuration.
offline(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Initiates taking a table offline, but does not wait for action to complete
offline(String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
offline(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
offline(String, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
OfflineCommand - Class in org.apache.accumulo.core.util.shell.commands
 
OfflineCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.OfflineCommand
 
OfflineScanner - Class in org.apache.accumulo.core.client.impl
 
OfflineScanner(Instance, Credentials, String, Authorizations) - Constructor for class org.apache.accumulo.core.client.impl.OfflineScanner
 
offset - Variable in class org.apache.accumulo.core.data.ArrayByteSequence
 
offset() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
offset() - Method in class org.apache.accumulo.core.data.ByteSequence
 
offset() - Method in class org.apache.accumulo.core.file.rfile.bcfile.ByteArray
 
offset() - Method in interface org.apache.accumulo.core.file.rfile.bcfile.RawComparable
Get the offset of the first byte in the byte array.
OLD_EXTENT - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
OLD_NAME - Static variable in class org.apache.accumulo.core.metadata.MetadataTable
 
OLD_PREV_ROW_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
A temporary field in case a split fails and we need to roll back
oldTablet - Variable in class org.apache.accumulo.core.master.thrift.TabletSplit
 
online(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Initiates bringing a table online, but does not wait for action to complete
online(String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
online(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
online(String, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
OnlineCommand - Class in org.apache.accumulo.core.util.shell.commands
 
OnlineCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.OnlineCommand
 
onlineTablets - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
op - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
op - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
openIndex(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations
 
openIndex(String, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.FileOperations
 
openIndex(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
openIndex(String, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
openIndex(Configuration, FileSystem, Path) - Static method in class org.apache.accumulo.core.file.map.MapFileUtil
 
openIndex(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openIndex(String, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openMapFile(AccumuloConfiguration, FileSystem, String, Configuration) - Static method in class org.apache.accumulo.core.file.map.MapFileUtil
 
openReader(String, Range, Set<ByteSequence>, boolean, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations
Open a reader that will not be seeked giving an initial seek location.
openReader(String, Range, Set<ByteSequence>, boolean, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.FileOperations
 
openReader(String, boolean, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations
Open a reader that fully support seeking and also enable any optimizations related to seeking, like bloom filters.
openReader(String, boolean, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.FileOperations
 
openReader(String, boolean, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
openReader(String, Range, Set<ByteSequence>, boolean, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
openReader(String, Range, Set<ByteSequence>, boolean, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
openReader(String, boolean, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
openReader(String, boolean, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openReader(String, boolean, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openReader(String, Range, Set<ByteSequence>, boolean, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openReader(String, Range, Set<ByteSequence>, boolean, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openWriter(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations
 
openWriter(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
openWriter(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
opid - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
opid - Variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
opid - Variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
opt - Variable in enum org.apache.accumulo.core.util.shell.commands.OptUtil.AdlOpt
 
OpTimer - Class in org.apache.accumulo.core.util
 
OpTimer(Logger, Level) - Constructor for class org.apache.accumulo.core.util.OpTimer
 
OptionDescriber - Interface in org.apache.accumulo.core.iterators
The OptionDescriber interface allows you to set up iterator properties interactively in the accumulo shell.
OptionDescriber.IteratorOptions - Class in org.apache.accumulo.core.iterators
 
OptionDescriber.IteratorOptions(String, String, Map<String, String>, List<String>) - Constructor for class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
IteratorOptions holds the name, description, and option information for an iterator.
options - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
optNamespace - Variable in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
optTableName - Variable in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
optTablePattern - Variable in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
OptUtil - Class in org.apache.accumulo.core.util.shell.commands
 
OptUtil() - Constructor for class org.apache.accumulo.core.util.shell.commands.OptUtil
 
OptUtil.AdlOpt - Enum in org.apache.accumulo.core.util.shell.commands
 
or(Filter) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
or(Filter) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
or(Filter) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Peforms a logical OR between this filter and a specified filter.
OR_FIELDS - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
org.apache.accumulo.core - package org.apache.accumulo.core
 
org.apache.accumulo.core.bloomfilter - package org.apache.accumulo.core.bloomfilter
 
org.apache.accumulo.core.cli - package org.apache.accumulo.core.cli
 
org.apache.accumulo.core.client - package org.apache.accumulo.core.client
 
org.apache.accumulo.core.client.admin - package org.apache.accumulo.core.client.admin
 
org.apache.accumulo.core.client.impl - package org.apache.accumulo.core.client.impl
 
org.apache.accumulo.core.client.impl.thrift - package org.apache.accumulo.core.client.impl.thrift
 
org.apache.accumulo.core.client.lexicoder - package org.apache.accumulo.core.client.lexicoder
 
org.apache.accumulo.core.client.lexicoder.impl - package org.apache.accumulo.core.client.lexicoder.impl
 
org.apache.accumulo.core.client.mapred - package org.apache.accumulo.core.client.mapred
 
org.apache.accumulo.core.client.mapreduce - package org.apache.accumulo.core.client.mapreduce
 
org.apache.accumulo.core.client.mapreduce.lib.impl - package org.apache.accumulo.core.client.mapreduce.lib.impl
This package exists to store common helpers for configuring MapReduce jobs in a single location.
org.apache.accumulo.core.client.mapreduce.lib.partition - package org.apache.accumulo.core.client.mapreduce.lib.partition
 
org.apache.accumulo.core.client.mapreduce.lib.util - package org.apache.accumulo.core.client.mapreduce.lib.util
 
org.apache.accumulo.core.client.mock - package org.apache.accumulo.core.client.mock
 
org.apache.accumulo.core.client.mock.impl - package org.apache.accumulo.core.client.mock.impl
 
org.apache.accumulo.core.client.security - package org.apache.accumulo.core.client.security
 
org.apache.accumulo.core.client.security.tokens - package org.apache.accumulo.core.client.security.tokens
 
org.apache.accumulo.core.conf - package org.apache.accumulo.core.conf
 
org.apache.accumulo.core.constraints - package org.apache.accumulo.core.constraints
 
org.apache.accumulo.core.data - package org.apache.accumulo.core.data
 
org.apache.accumulo.core.data.thrift - package org.apache.accumulo.core.data.thrift
 
org.apache.accumulo.core.file - package org.apache.accumulo.core.file
 
org.apache.accumulo.core.file.blockfile - package org.apache.accumulo.core.file.blockfile
 
org.apache.accumulo.core.file.blockfile.cache - package org.apache.accumulo.core.file.blockfile.cache
 
org.apache.accumulo.core.file.blockfile.impl - package org.apache.accumulo.core.file.blockfile.impl
 
org.apache.accumulo.core.file.keyfunctor - package org.apache.accumulo.core.file.keyfunctor
 
org.apache.accumulo.core.file.map - package org.apache.accumulo.core.file.map
 
org.apache.accumulo.core.file.rfile - package org.apache.accumulo.core.file.rfile
 
org.apache.accumulo.core.file.rfile.bcfile - package org.apache.accumulo.core.file.rfile.bcfile
 
org.apache.accumulo.core.gc.thrift - package org.apache.accumulo.core.gc.thrift
 
org.apache.accumulo.core.iterators - package org.apache.accumulo.core.iterators
 
org.apache.accumulo.core.iterators.aggregation - package org.apache.accumulo.core.iterators.aggregation
 
org.apache.accumulo.core.iterators.aggregation.conf - package org.apache.accumulo.core.iterators.aggregation.conf
 
org.apache.accumulo.core.iterators.conf - package org.apache.accumulo.core.iterators.conf
 
org.apache.accumulo.core.iterators.system - package org.apache.accumulo.core.iterators.system
 
org.apache.accumulo.core.iterators.user - package org.apache.accumulo.core.iterators.user
 
org.apache.accumulo.core.master - package org.apache.accumulo.core.master
 
org.apache.accumulo.core.master.state.tables - package org.apache.accumulo.core.master.state.tables
 
org.apache.accumulo.core.master.thrift - package org.apache.accumulo.core.master.thrift
 
org.apache.accumulo.core.metadata - package org.apache.accumulo.core.metadata
 
org.apache.accumulo.core.metadata.schema - package org.apache.accumulo.core.metadata.schema
 
org.apache.accumulo.core.security - package org.apache.accumulo.core.security
 
org.apache.accumulo.core.security.crypto - package org.apache.accumulo.core.security.crypto
 
org.apache.accumulo.core.security.thrift - package org.apache.accumulo.core.security.thrift
 
org.apache.accumulo.core.tabletserver.log - package org.apache.accumulo.core.tabletserver.log
 
org.apache.accumulo.core.tabletserver.thrift - package org.apache.accumulo.core.tabletserver.thrift
 
org.apache.accumulo.core.trace - package org.apache.accumulo.core.trace
 
org.apache.accumulo.core.util - package org.apache.accumulo.core.util
 
org.apache.accumulo.core.util.format - package org.apache.accumulo.core.util.format
 
org.apache.accumulo.core.util.interpret - package org.apache.accumulo.core.util.interpret
 
org.apache.accumulo.core.util.shell - package org.apache.accumulo.core.util.shell
 
org.apache.accumulo.core.util.shell.commands - package org.apache.accumulo.core.util.shell.commands
 
org.apache.accumulo.core.volume - package org.apache.accumulo.core.volume
 
org.apache.accumulo.core.zookeeper - package org.apache.accumulo.core.zookeeper
 
OrIterator - Class in org.apache.accumulo.core.iterators
An iterator that handles "OR" query constructs on the server side.
OrIterator() - Constructor for class org.apache.accumulo.core.iterators.OrIterator
 
OrIterator.TermSource - Class in org.apache.accumulo.core.iterators
 
OrIterator.TermSource(OrIterator.TermSource) - Constructor for class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
OrIterator.TermSource(SortedKeyValueIterator<Key, Value>, Text) - Constructor for class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
osLoad - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
out - Variable in class org.apache.accumulo.core.client.mock.MockShell
 
out - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
OutputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
 
OutputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
 
OutputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
OutputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
 
OutputConfigurator.Features - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
Configuration keys for various features.
OutputConfigurator.Features - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
OutputConfigurator.WriteOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
Configuration keys for BatchWriter.
OutputConfigurator.WriteOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
outputFile - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
overlaps(KeyExtent) - Method in class org.apache.accumulo.core.data.KeyExtent
 
overrideCurrentTime(long) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 

P

Pair<A,B> - Class in org.apache.accumulo.core.util
 
Pair(A, B) - Constructor for class org.apache.accumulo.core.util.Pair
 
PairLexicoder<A extends Comparable<A>,B extends Comparable<B>> - Class in org.apache.accumulo.core.client.lexicoder
This class is a lexicoder that sorts a ComparablePair.
PairLexicoder(Lexicoder<A>, Lexicoder<B>) - Constructor for class org.apache.accumulo.core.client.lexicoder.PairLexicoder
 
parent - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
parseAddress(String) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
parseAddress(String, boolean) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
parseAddress(String, int) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
parseArgs(String, String[], Object...) - Method in class org.apache.accumulo.core.cli.ClientOpts
 
parseArgs(String, String[], Object...) - Method in class org.apache.accumulo.core.cli.Help
 
parseCipherTransform(String) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
 
parseDocID(Key) - Static method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
parseIterConf(IteratorUtil.IteratorScope, List<IterInfo>, Map<String, Map<String, String>>, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
PartialKey - Enum in org.apache.accumulo.core.data
 
partition(List<Mutation>, List<Mutation>[]) - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.Partitioner
 
partNextKey - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
partNextKeyInclusive - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
partScan - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
PasswdCommand - Class in org.apache.accumulo.core.util.shell.commands
 
PasswdCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.PasswdCommand
 
password - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
password - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
password - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
password - Variable in class org.apache.accumulo.core.trace.InstanceUserPassword
 
PasswordToken - Class in org.apache.accumulo.core.client.security.tokens
 
PasswordToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.PasswordToken
Constructor for use with Writable.
PasswordToken(CharSequence) - Constructor for class org.apache.accumulo.core.client.security.tokens.PasswordToken
Constructs a token from a copy of the password.
PasswordToken(byte[]) - Constructor for class org.apache.accumulo.core.client.security.tokens.PasswordToken
Constructs a token from a copy of the password.
PasswordToken(ByteBuffer) - Constructor for class org.apache.accumulo.core.client.security.tokens.PasswordToken
Constructs a token from a copy of the password.
PATH_PROPERTY_ENV_VARS - Static variable in class org.apache.accumulo.core.Constants
 
peek() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
peek() - Method in class org.apache.accumulo.core.util.PeekingIterator
 
PeekingIterator<E> - Class in org.apache.accumulo.core.util
 
PeekingIterator(Iterator<E>) - Constructor for class org.apache.accumulo.core.util.PeekingIterator
 
PeekingIterator() - Constructor for class org.apache.accumulo.core.util.PeekingIterator
Creates an uninitialized instance.
peekPrevious() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
PER_BLOCK_OVERHEAD - Static variable in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
PerColumnIteratorConfig - Class in org.apache.accumulo.core.iterators.conf
Deprecated.
since 1.4
PerColumnIteratorConfig(Text, String) - Constructor for class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
Deprecated.
 
PerColumnIteratorConfig(Text, Text, String) - Constructor for class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
Deprecated.
 
permission - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
permission - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
permission - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
permission - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
permission - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
permission - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
ping(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Throws an exception if a tablet server can not be contacted.
ping(String) - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
ping(TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
ping(TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
ping(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
ping(TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
PingCommand - Class in org.apache.accumulo.core.util.shell.commands
 
PingCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.PingCommand
 
prefix() - Method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.TokenSource
 
prefix(Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all rows beginning with a prefix
prefix(Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column families beginning with a prefix within a given row
prefix(Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column qualifiers beginning with a prefix within a given row and column family
prefix(Text, Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column visibilities beginning with a prefix within a given row, column family, and column qualifier
prefix(CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all rows beginning with a prefix
prefix(CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column families beginning with a prefix within a given row
prefix(CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column qualifiers beginning with a prefix within a given row and column family
prefix(CharSequence, CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column visibilities beginning with a prefix within a given row, column family, and column qualifier
prefix(String[], String) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
prefixChild(Path) - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
 
prefixChild(String) - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
 
prefixChild(Path) - Method in interface org.apache.accumulo.core.volume.Volume
Convert the given Path into a Path that is relative to the base path for this Volume
prefixChild(String) - Method in interface org.apache.accumulo.core.volume.Volume
Convert the given child path into a Path that is relative to the base path for this Volume
prefixChild(Path) - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
prefixChild(String) - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
prepareDataBlock() - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileWriter
 
prepareDataBlock() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
 
prepareDataBlock() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Create a Data Block and obtain an output stream for adding data into the block.
prepareMetaBlock(String, String) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileWriter
 
prepareMetaBlock(String) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileWriter
 
prepareMetaBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
 
prepareMetaBlock(String, String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
 
prepareMetaBlock(String, String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Create a Meta Block and obtain an output stream for adding data into the block.
prepareMetaBlock(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Create a Meta Block and obtain an output stream for adding data into the block.
PREV_ROW_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
README : very important that prevRow sort last to avoid race conditions between garbage collector and split this needs to sort after everything else for that tablet
prevEndRow - Variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
previous() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
previousIndex() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
principal - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
principal - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
principal - Variable in class org.apache.accumulo.core.security.thrift.TCredentials
 
print(String) - Method in interface org.apache.accumulo.core.trace.TraceDump.Printer
 
print(String) - Method in class org.apache.accumulo.core.util.shell.Shell.PrintFile
 
print(String) - Method in interface org.apache.accumulo.core.util.shell.Shell.PrintLine
 
print(String) - Method in class org.apache.accumulo.core.util.shell.Shell.PrintShell
 
print() - Method in class org.apache.accumulo.core.util.StopWatch
 
printableValues() - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Returns a list of printable permission values.
printableValues() - Static method in enum org.apache.accumulo.core.security.SystemPermission
Returns a list of printable permission values.
printableValues() - Static method in enum org.apache.accumulo.core.security.TablePermission
Returns a list of printable permission values.
printBinaryRecords(CommandLine, Shell, Iterable<Map.Entry<Key, Value>>) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
printBinaryRecords(CommandLine, Shell, Iterable<Map.Entry<Key, Value>>, Shell.PrintFile) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
printBinaryRecords(Iterable<Map.Entry<Key, Value>>, boolean, boolean, Shell.PrintLine) - Method in class org.apache.accumulo.core.util.shell.Shell
 
printBinaryRecords(Iterable<Map.Entry<Key, Value>>, boolean, boolean) - Method in class org.apache.accumulo.core.util.shell.Shell
 
printException(Exception) - Method in class org.apache.accumulo.core.util.shell.Shell
 
printHelp(Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
printHelp(Shell, int) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
PrintInfo - Class in org.apache.accumulo.core.file.rfile.bcfile
 
PrintInfo() - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.PrintInfo
 
PrintInfo - Class in org.apache.accumulo.core.file.rfile
 
PrintInfo() - Constructor for class org.apache.accumulo.core.file.rfile.PrintInfo
 
printInfo() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
printInfo() - Method in class org.apache.accumulo.core.util.shell.Shell
 
printLines(Iterator<String>, boolean) - Method in class org.apache.accumulo.core.util.shell.Shell
 
printLines(Iterator<String>, boolean, Shell.PrintLine) - Method in class org.apache.accumulo.core.util.shell.Shell
 
printMetaBlockInfo(Configuration, FileSystem, Path, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.PrintInfo
 
printRecords(CommandLine, Shell, Iterable<Map.Entry<Key, Value>>, Class<? extends Formatter>) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
printRecords(CommandLine, Shell, Iterable<Map.Entry<Key, Value>>, Class<? extends Formatter>, Shell.PrintFile) - Method in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
printRecords(Iterable<Map.Entry<Key, Value>>, boolean, boolean, Class<? extends Formatter>, Shell.PrintLine) - Method in class org.apache.accumulo.core.util.shell.Shell
 
printRecords(Iterable<Map.Entry<Key, Value>>, boolean, boolean, Class<? extends Formatter>) - Method in class org.apache.accumulo.core.util.shell.Shell
 
printTrace(Scanner, TraceDump.Printer) - Static method in class org.apache.accumulo.core.trace.TraceDump
 
printVerboseInfo() - Method in class org.apache.accumulo.core.util.shell.Shell
 
priority - Variable in class org.apache.accumulo.core.data.thrift.IterInfo
 
priority - Variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
process(WatchedEvent) - Method in class org.apache.accumulo.core.trace.ZooTraceClient
 
progress - Variable in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
properties - Variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
propertiesChanged() - Method in interface org.apache.accumulo.core.conf.ConfigurationObserver
 
propertiesChanged() - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
Notifies all observers that properties changed.
Property - Enum in org.apache.accumulo.core.conf
 
property - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
property - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
property - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
property - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
property - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
property - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
propertyChanged(String) - Method in interface org.apache.accumulo.core.conf.ConfigurationObserver
 
propertyChanged(String) - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
Notifies all observers that a property changed.
PropertyType - Enum in org.apache.accumulo.core.conf
 
protocolFactory() - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
pruneTables(String, Set<String>) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteTableCommand
 
pruneTables(String, Set<String>) - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
Allows implementation to remove certain tables from the set of tables to be operated on.
put(String, CharSequence) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
put(String, char[]) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
put(Text, Text, Value) - Method in class org.apache.accumulo.core.data.Mutation
 
put(Text, Text, ColumnVisibility, Value) - Method in class org.apache.accumulo.core.data.Mutation
 
put(Text, Text, long, Value) - Method in class org.apache.accumulo.core.data.Mutation
 
put(Text, Text, ColumnVisibility, long, Value) - Method in class org.apache.accumulo.core.data.Mutation
 
put(CharSequence, CharSequence, Value) - Method in class org.apache.accumulo.core.data.Mutation
 
put(CharSequence, CharSequence, ColumnVisibility, Value) - Method in class org.apache.accumulo.core.data.Mutation
 
put(CharSequence, CharSequence, long, Value) - Method in class org.apache.accumulo.core.data.Mutation
 
put(CharSequence, CharSequence, ColumnVisibility, long, Value) - Method in class org.apache.accumulo.core.data.Mutation
 
put(CharSequence, CharSequence, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
 
put(CharSequence, CharSequence, ColumnVisibility, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
 
put(CharSequence, CharSequence, long, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
 
put(CharSequence, CharSequence, ColumnVisibility, long, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
 
put(byte[], byte[], byte[]) - Method in class org.apache.accumulo.core.data.Mutation
 
put(byte[], byte[], ColumnVisibility, byte[]) - Method in class org.apache.accumulo.core.data.Mutation
 
put(byte[], byte[], long, byte[]) - Method in class org.apache.accumulo.core.data.Mutation
 
put(byte[], byte[], ColumnVisibility, long, byte[]) - Method in class org.apache.accumulo.core.data.Mutation
 
put(Mutation, Value) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
putAll(Map<? extends String, ? extends char[]>) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
putAllStrings(Map<String, ? extends CharSequence>) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
putDelete(Text, Text) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(Text, Text, ColumnVisibility) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(Text, Text, long) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(Text, Text, ColumnVisibility, long) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(CharSequence, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(CharSequence, CharSequence, ColumnVisibility) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(CharSequence, CharSequence, long) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(CharSequence, CharSequence, ColumnVisibility, long) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(byte[], byte[]) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(byte[], byte[], ColumnVisibility) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(byte[], byte[], long) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(byte[], byte[], ColumnVisibility, long) - Method in class org.apache.accumulo.core.data.Mutation
 
putDelete(Mutation) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
putToAuthorizationFailures(TKeyExtent, SecurityErrorCode) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
putToBadTServers(String, byte) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
putToBatch(TKeyExtent, List<TRange>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
putToFailedExtents(TKeyExtent, long) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
putToFailures(TKeyExtent, List<TRange>) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
putToFiles(TKeyExtent, Map<String, MapFileInfo>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
putToMutations(TKeyExtent, List<TConditionalMutation>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
putToOptions(String, String) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
putToProperties(String, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
putToSsio(String, Map<String, String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
putToSsio(String, Map<String, String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
putToSsio(String, Map<String, String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
putToSsio(String, Map<String, String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
putToTableMap(String, TableInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
putToTableMap(String, TableInfo) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
PW_HASH_ALGORITHM - Static variable in class org.apache.accumulo.core.Constants
 

Q

qualified(String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
qualified(String, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
qualify(String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
qualify(String, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
queryByteRate - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
queryRate - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
queryRate - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
QuestionCommand - Class in org.apache.accumulo.core.util.shell.commands
 
QuestionCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.QuestionCommand
 
queued - Variable in class org.apache.accumulo.core.master.thrift.Compacting
 
queueSumDev - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
queueTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
QuitCommand - Class in org.apache.accumulo.core.util.shell.commands
 
QuitCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.QuitCommand
 
quote(String) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
Properly quotes terms in a column visibility expression.
quote(byte[]) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
Properly quotes terms in a column visibility expression.
QuotedStringTokenizer - Class in org.apache.accumulo.core.util.shell.commands
A basic tokenizer for generating tokens from a string.
QuotedStringTokenizer(String) - Constructor for class org.apache.accumulo.core.util.shell.commands.QuotedStringTokenizer
 

R

Range - Class in org.apache.accumulo.core.data
This class is used to specify a range of Accumulo Keys.
Range() - Constructor for class org.apache.accumulo.core.data.Range
Creates a range that goes from negative to positive infinity
Range(Key, Key) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startKey inclusive to endKey inclusive
Range(CharSequence) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range that covers an entire row
Range(Text) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range that covers an entire row
Range(Text, Text) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow inclusive to endRow inclusive
Range(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow inclusive to endRow inclusive
Range(Text, boolean, Text, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow to endRow
Range(CharSequence, boolean, CharSequence, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow to endRow
Range(Key, boolean, Key, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startKey to endKey
Range(Range) - Constructor for class org.apache.accumulo.core.data.Range
Copies a range
Range(Key, Key, boolean, boolean, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from start to stop.
Range(Key, boolean, boolean, Key, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from start to stop.
Range(TRange) - Constructor for class org.apache.accumulo.core.data.Range
 
range - Variable in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
range - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
RangeInputSplit - Class in org.apache.accumulo.core.client.mapred
The Class RangeInputSplit.
RangeInputSplit() - Constructor for class org.apache.accumulo.core.client.mapred.RangeInputSplit
 
RangeInputSplit(RangeInputSplit) - Constructor for class org.apache.accumulo.core.client.mapred.RangeInputSplit
 
RangeInputSplit(String, String, Range, String[]) - Constructor for class org.apache.accumulo.core.client.mapred.RangeInputSplit
 
RangeInputSplit - Class in org.apache.accumulo.core.client.mapreduce
The Class RangeInputSplit.
RangeInputSplit() - Constructor for class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
RangeInputSplit(RangeInputSplit) - Constructor for class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
RangeInputSplit(String, String, Range, String[]) - Constructor for class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
RangePartitioner - Class in org.apache.accumulo.core.client.mapreduce.lib.partition
Hadoop partitioner that uses ranges, and optionally sub-bins based on hashing.
RangePartitioner() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
 
RawComparable - Interface in org.apache.accumulo.core.file.rfile.bcfile
Interface for objects that can be compared through RawComparator.
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
read(TProtocol) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
read(TProtocol) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
read(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
read() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
read(byte[], int, int) - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
read(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
read(DataInputStream) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
read(DataInputStream) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.FixedLongArrayEncoder
 
read(DataInputStream) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.VarLongArrayEncoder
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
read(TProtocol) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
read() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
 
read(byte[], int, int) - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
 
read(TProtocol) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
readaheadThreshold - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
readBoolean() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
 
readBytes(byte[]) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
 
reader - Variable in class org.apache.accumulo.core.util.shell.Shell
 
readFields(DataInput) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
readFields(DataInput) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
readFields(DataInput) - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.IteratorSetting
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Reads the fields in the DataInput into the current object
readFields(DataInput) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Column
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Key
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.KeyExtent
Populates the extents data fields from a DataInput object
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Mutation
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Range
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Value
 
readFields(DataInput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
readFields(DataInput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
readFields(DataInput) - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
readInt() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
 
readLong() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
 
readMaskedLine(String, Character) - Method in class org.apache.accumulo.core.util.shell.Shell
 
readString(DataInput) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Read a String as a VInt n, followed by n Bytes in Text format.
readVInt(DataInput) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Decoding the variable-length integer.
readVInt() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
 
readVLong(DataInput) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Decoding the variable-length integer.
readVLong() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
 
reason - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
receive(List<Map.Entry<Key, Value>>) - Method in interface org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator.ResultReceiver
 
RecoveryException - Exception in org.apache.accumulo.core.master.thrift
 
RecoveryException() - Constructor for exception org.apache.accumulo.core.master.thrift.RecoveryException
 
RecoveryException(String) - Constructor for exception org.apache.accumulo.core.master.thrift.RecoveryException
 
RecoveryException(RecoveryException) - Constructor for exception org.apache.accumulo.core.master.thrift.RecoveryException
Performs a deep copy on other.
RecoveryException._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RecoveryStatus - Class in org.apache.accumulo.core.master.thrift
 
RecoveryStatus() - Constructor for class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
RecoveryStatus(String, int, double) - Constructor for class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
RecoveryStatus(RecoveryStatus) - Constructor for class org.apache.accumulo.core.master.thrift.RecoveryStatus
Performs a deep copy on other.
RecoveryStatus._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
recs - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
recsInMemory - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
recv_authenticate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_authenticateUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_beginFateOperation() - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
recv_bulkImport() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_bulkImportFiles() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_changeAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_changeLocalUserPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_checkClass() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_checkNamespaceClass() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_checkTableClass() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_closeMultiScan() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_closeUpdate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_conditionalUpdate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_continueMultiScan() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_continueScan() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_createLocalUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_dropLocalUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_executeFateOperation() - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
recv_fails() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
recv_finishFateOperation() - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
recv_getActiveCompactions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_getActiveScans() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_getConfiguration() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_getDiskUsage() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_getHistoricalStats() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_getInstanceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_getMasterStats() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_getNamespaceConfiguration() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_getRootTabletLocation() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_getStatus() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
recv_getTableConfiguration() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_getTabletServerStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_getTabletStats() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_getUserAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_getZooKeepers() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_grantNamespacePermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_grantSystemPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_grantTablePermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_halt() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_hasNamespacePermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_hasSystemPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_hasTablePermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_initiateFlush() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_invalidateConditionalUpdate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_isActive() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_listLocalUsers() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_ping() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_removeNamespaceProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_removeSystemProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_removeTableProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_revokeNamespacePermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_revokeSystemPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_revokeTablePermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_setMasterGoalState() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_setNamespaceProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_setSystemProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_setTableProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_shutdown() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_shutdownTabletServer() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_splitTablet() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_startConditionalUpdate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_startMultiScan() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_startScan() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_startUpdate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_success() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
recv_throwsError() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
recv_update() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_waitForFateOperation() - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
recv_waitForFlush() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
reduce(Key, Iterator<Value>) - Method in class org.apache.accumulo.core.iterators.Combiner
Reduces a list of Values into a single Value.
reduce(Key, Iterator<Value>) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
REDUCE_ON_FULL_COMPACTION_ONLY_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
 
REENTRANT_LOCK - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for ReentrantReadWriteLock
REFERENCE - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Reference size is 8 bytes on 64-bit, 4 bytes on 32-bit
RegExFilter - Class in org.apache.accumulo.core.iterators.user
A Filter that matches entries based on Java regular expressions.
RegExFilter() - Constructor for class org.apache.accumulo.core.iterators.user.RegExFilter
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.AddAuthsCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.AuthenticateCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.CloneTableCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.ConfigCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.CreateTableCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.DebugCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.DeleteNamespaceCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.DropUserCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.ExportTableCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.GrantCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.HelpCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.RenameNamespaceCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.RenameTableCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.RevokeCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.SetAuthsCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.TableCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.commands.UserCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
registerCompletionForCommands(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
registerCompletionForNamespaces(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
registerCompletionForTables(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
registerCompletionForUsers(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
registerCompletionGeneral(Token, Set<String>, boolean) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
registerSideChannel(SortedKeyValueIterator<Key, Value>) - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
RelativeKey - Class in org.apache.accumulo.core.file.rfile
 
RelativeKey() - Constructor for class org.apache.accumulo.core.file.rfile.RelativeKey
This constructor is used when one needs to read from an input stream
RelativeKey(Key, Key) - Constructor for class org.apache.accumulo.core.file.rfile.RelativeKey
This constructor is used when constructing a key for writing to an output stream
RelativeKey.SkippR - Class in org.apache.accumulo.core.file.rfile
 
remove() - Method in class org.apache.accumulo.core.client.impl.ScannerIterator
 
remove() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator
 
remove() - Method in class org.apache.accumulo.core.client.mock.IteratorAdapter
 
remove() - Method in class org.apache.accumulo.core.client.RowIterator
Unsupported.
remove(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
remove() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
remove() - Method in class org.apache.accumulo.core.iterators.Combiner.ValueIterator
This method is unsupported in this iterator.
remove() - Method in class org.apache.accumulo.core.trace.TraceFormatter
 
remove() - Method in class org.apache.accumulo.core.util.format.DateStringFormatter
 
remove() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
remove() - Method in class org.apache.accumulo.core.util.format.HexFormatter
 
remove() - Method in class org.apache.accumulo.core.util.PeekingIterator
 
removeConstraint(String, int) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Remove a constraint from a namespace.
removeConstraint(String, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Remove a constraint from a table.
removeConstraint(String, int) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
removeConstraint(String, int) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
removeIterator(String, String, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Remove an iterator from a namespace by name.
removeIterator(String, String, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Remove an iterator from a table by name.
removeIterator(String, String, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
removeIterator(String, String, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
removeLogs(TInfo, TCredentials, List<String>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
removeLogs(TInfo, TCredentials, List<String>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
removeLogs(TInfo, TCredentials, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
removeLogs(TInfo, TCredentials, List<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
removeNamespaceProperty(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
removeNamespaceProperty(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
removeNamespaceProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
removeNamespaceProperty(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
removeObserver(ConfigurationObserver) - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
Removes an observer.
removeOption(String) - Method in class org.apache.accumulo.core.client.IteratorSetting
Remove an option from the iterator.
removePlugin(CommandLine, Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.FormatterCommand
 
removePlugin(CommandLine, Shell, String) - Method in class org.apache.accumulo.core.util.shell.commands.ShellPluginConfigurationCommand
 
removeProperty(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Removes a system property from zookeeper.
removeProperty(String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Removes a property from a namespace.
removeProperty(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Removes a property from a table.
removeProperty(String) - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
removeProperty(String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
removeProperty(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Removes a property from a table
removeScanIterator(String) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
removeScanIterator(String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Remove an iterator from the list of iterators.
removeSystemProperty(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
removeSystemProperty(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
removeSystemProperty(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
removeSystemProperty(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
removeTableProperty(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
removeTableProperty(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
removeTableProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
removeTableProperty(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
removeTTL(IteratorSetting, IteratorSetting.Column) - Static method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
A convenience method for removing an age off threshold for a column.
rename(String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Rename a namespace
rename(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Rename a table
rename(String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
rename(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Rename a table
RenameNamespaceCommand - Class in org.apache.accumulo.core.util.shell.commands
 
RenameNamespaceCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.RenameNamespaceCommand
 
RenameTableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
RenameTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.RenameTableCommand
 
repeat(String, int) - Static method in class org.apache.accumulo.core.util.shell.Shell
 
replaceColumnFamily(Key, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with all parts (including delete flag) coming from originalKey but use newColFam as the column family.
replaceColumnQualifier(Key, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with all parts (including delete flag) coming from originalKey but use newColQual as the column qualifier.
replaceColumnVisibility(Key, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with all parts (including delete flag) coming from originalKey but use newColVis as the column visibility.
replaceKeyParts(Key, Text, Text, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with a column family, column qualifier, and column visibility.
replaceKeyParts(Key, Text, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with a column qualifier, and column visibility.
report() - Method in class org.apache.accumulo.core.iterators.system.StatsIterator
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
ReqVisFilter - Class in org.apache.accumulo.core.iterators.user
A Filter that matches entries with a non-empty ColumnVisibility.
ReqVisFilter() - Constructor for class org.apache.accumulo.core.iterators.user.ReqVisFilter
 
reseek(Key) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
reserveMapFileReader(String) - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
reset() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
reset() - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
Deprecated.
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
Deprecated.
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
Deprecated.
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
Deprecated.
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
Deprecated.
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
Deprecated.
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
Deprecated.
 
reset() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
 
reset(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
resetExitCode() - Method in class org.apache.accumulo.core.util.shell.Shell
 
result - Variable in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
result - Variable in class org.apache.accumulo.core.data.thrift.InitialScan
 
results - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
results - Variable in class org.apache.accumulo.core.data.thrift.ScanResult
 
returnClient(TServiceClient) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
returnCompressor(Compressor) - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
returnDecompressor(Decompressor) - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
 
returnTransport(TTransport) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
ReverseLexicoder<T> - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder that flips the sort order from another lexicoder.
ReverseLexicoder(Lexicoder<T>) - Constructor for class org.apache.accumulo.core.client.lexicoder.ReverseLexicoder
 
RevokeCommand - Class in org.apache.accumulo.core.util.shell.commands
 
RevokeCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.RevokeCommand
 
revokeNamespacePermission(String, String, NamespacePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Revoke a namespace permission for a specific user on a specific namespace
revokeNamespacePermission(String, String, NamespacePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
revokeNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
revokeNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
revokeNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
revokeNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
revokeSystemPermission(String, SystemPermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Revoke a system permission from a user
revokeSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
revokeSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
revokeSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
revokeSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
revokeSystemPermission(TInfo, TCredentials, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
revokeTablePermission(String, String, TablePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Revoke a table permission for a specific user on a specific table
revokeTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
revokeTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
 
revokeTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
 
revokeTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
revokeTablePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
RFile - Class in org.apache.accumulo.core.file.rfile
 
RFile.Reader - Class in org.apache.accumulo.core.file.rfile
 
RFile.Reader(BlockFileReader) - Constructor for class org.apache.accumulo.core.file.rfile.RFile.Reader
 
RFile.Writer - Class in org.apache.accumulo.core.file.rfile
 
RFile.Writer(BlockFileWriter, int) - Constructor for class org.apache.accumulo.core.file.rfile.RFile.Writer
 
RFile.Writer(BlockFileWriter, int, int) - Constructor for class org.apache.accumulo.core.file.rfile.RFile.Writer
 
RFileOperations - Class in org.apache.accumulo.core.file.rfile
 
RFileOperations() - Constructor for class org.apache.accumulo.core.file.rfile.RFileOperations
 
ROOT_TABLET_LOCATION - Static variable in class org.apache.accumulo.core.metadata.RootTable
DFS location relative to the Accumulo directory
RootTable - Class in org.apache.accumulo.core.metadata
 
RootTable() - Constructor for class org.apache.accumulo.core.metadata.RootTable
 
RootTabletLocator - Class in org.apache.accumulo.core.client.impl
 
row - Variable in class org.apache.accumulo.core.data.Key
 
row - Variable in class org.apache.accumulo.core.data.thrift.TKey
 
row - Variable in class org.apache.accumulo.core.data.thrift.TMutation
 
ROW_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
rowDecoder(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
Given a value generated by the rowEncoder implementation, recreate the original Key, Value pairs.
rowDecoder(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
RowDeletingIterator - Class in org.apache.accumulo.core.iterators
Deprecated.
since 1.4, replaced by RowDeletingIterator
RowDeletingIterator() - Constructor for class org.apache.accumulo.core.iterators.RowDeletingIterator
Deprecated.
 
RowDeletingIterator - Class in org.apache.accumulo.core.iterators.user
An iterator for deleting whole rows.
RowDeletingIterator() - Constructor for class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
rowEncoder(List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
Take a stream of keys and values.
rowEncoder(List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
RowEncodingIterator - Class in org.apache.accumulo.core.iterators.user
The RowEncodingIterator is designed to provide row-isolation so that queries see mutations as atomic.
RowEncodingIterator() - Constructor for class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
RowFilter - Class in org.apache.accumulo.core.iterators.user
This iterator makes it easy to select rows that meet a given criteria.
RowFilter() - Constructor for class org.apache.accumulo.core.iterators.user.RowFilter
 
RowFunctor - Class in org.apache.accumulo.core.file.keyfunctor
 
RowFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.RowFunctor
 
RowIterator - Class in org.apache.accumulo.core.client
Group Key/Value pairs into Iterators over rows.
RowIterator(Iterator<Map.Entry<Key, Value>>) - Constructor for class org.apache.accumulo.core.client.RowIterator
Create an iterator from an (ordered) sequence of KeyValue pairs.
RowIterator(Iterable<Map.Entry<Key, Value>>) - Constructor for class org.apache.accumulo.core.client.RowIterator
Create an iterator from an Iterable.
RT - Static variable in class org.apache.accumulo.core.client.impl.Translators
 
run() - Method in class org.apache.accumulo.core.util.LoggingRunnable
 
running - Variable in class org.apache.accumulo.core.master.thrift.Compacting
 
runtime - Variable in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 

S

safeAdd(long, long) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
Deprecated.
 
safeAdd(long, long) - Static method in class org.apache.accumulo.core.iterators.LongCombiner
 
save - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
scan(Instance, Credentials, ThriftScanner.ScanState, int, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.client.impl.ThriftScanner
 
SCAN_BATCH_SIZE - Static variable in class org.apache.accumulo.core.Constants
 
scanBatchSize - Variable in class org.apache.accumulo.core.cli.ScannerOpts
 
ScanCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ScanCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
scanID - Variable in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
scanID - Variable in class org.apache.accumulo.core.data.thrift.InitialScan
 
scanId - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
scanID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
scanID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
scanID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
scanID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
ScanInterpreter - Interface in org.apache.accumulo.core.util.interpret
A simple interface for creating shell plugins that translate the range and column arguments for the shell's scan command.
scanIteratorOptions - Variable in class org.apache.accumulo.core.util.shell.Shell
 
scanner - Variable in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
 
Scanner - Interface in org.apache.accumulo.core.client
Scans a table over a given range.
SCANNER_DEFAULT_READAHEAD_THRESHOLD - Static variable in class org.apache.accumulo.core.Constants
 
ScannerBase - Interface in org.apache.accumulo.core.client
This class hosts configuration methods that are shared between different types of scanners.
ScannerImpl - Class in org.apache.accumulo.core.client.impl
provides scanner functionality "Clients can iterate over multiple column families, and there are several mechanisms for limiting the rows, columns, and timestamps traversed by a scan.
ScannerImpl(Instance, Credentials, String, Authorizations) - Constructor for class org.apache.accumulo.core.client.impl.ScannerImpl
 
ScannerIterator - Class in org.apache.accumulo.core.client.impl
 
scannerIterator - Variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
 
scannerIterator - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
 
ScannerOptions - Class in org.apache.accumulo.core.client.impl
 
ScannerOptions() - Constructor for class org.apache.accumulo.core.client.impl.ScannerOptions
 
ScannerOptions(ScannerOptions) - Constructor for class org.apache.accumulo.core.client.impl.ScannerOptions
 
ScannerOpts - Class in org.apache.accumulo.core.cli
 
ScannerOpts() - Constructor for class org.apache.accumulo.core.cli.ScannerOpts
 
scanning - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
scanRate - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
ScanResult - Class in org.apache.accumulo.core.data.thrift
 
ScanResult() - Constructor for class org.apache.accumulo.core.data.thrift.ScanResult
 
ScanResult(List<TKeyValue>, boolean) - Constructor for class org.apache.accumulo.core.data.thrift.ScanResult
 
ScanResult(ScanResult) - Constructor for class org.apache.accumulo.core.data.thrift.ScanResult
Performs a deep copy on other.
ScanResult._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
scans - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
ScanState - Enum in org.apache.accumulo.core.client.admin
 
ScanState - Enum in org.apache.accumulo.core.tabletserver.thrift
 
scanThreads - Variable in class org.apache.accumulo.core.cli.BatchScannerOpts
 
scanTimeout - Variable in class org.apache.accumulo.core.cli.BatchScannerOpts
 
ScanType - Enum in org.apache.accumulo.core.client.admin
 
ScanType - Enum in org.apache.accumulo.core.tabletserver.thrift
 
script - Variable in class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
ScriptCommand - Class in org.apache.accumulo.core.util.shell.commands
 
ScriptCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.ScriptCommand
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
sec - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
SecretKeyEncryptionStrategy - Interface in org.apache.accumulo.core.security.crypto
 
securePassword - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
SecurityErrorCode - Enum in org.apache.accumulo.core.client.impl.thrift
 
SecurityErrorCode - Enum in org.apache.accumulo.core.client.security
 
SecurityOperations - Interface in org.apache.accumulo.core.client.admin
Provides a class for managing users and permissions
securityOperations() - Method in class org.apache.accumulo.core.client.Connector
Retrieves a SecurityOperations object to perform user security operations, such as creating users.
securityOperations() - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
securityOperations() - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
SecurityOperationsImpl - Class in org.apache.accumulo.core.client.admin
Deprecated.
since 1.6.0; not intended for public api and you should not use it.
SecurityOperationsImpl(Instance, Credentials) - Constructor for class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
Deprecated.
 
SecurityOperationsImpl(Instance, TCredentials) - Constructor for class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
Deprecated.
 
SecurityOperationsImpl - Class in org.apache.accumulo.core.client.impl
 
SecurityOperationsImpl(Instance, Credentials) - Constructor for class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
 
seek(int) - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
 
seek(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
 
seek(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
seek(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.Combiner
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.DevNull
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.Filter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.SkippingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Seeks to the first key in the Range, restricting the resulting K,V pairs to those with the specified columns.
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.DeletingIterator
 
seek(HeapIterator, LocalityGroupIterator.LocalityGroup[], Set<ByteSequence>, Range, Collection<ByteSequence>, boolean) - Static method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.MultiIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.StatsIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
SeekableByteArrayInputStream - Class in org.apache.accumulo.core.file.blockfile.impl
This class is like byte array input stream with two differences.
SeekableByteArrayInputStream(byte[]) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
SeekableByteArrayInputStream(byte[], int) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
seekBlock(Key, ABlockReader) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex
 
seekColfams - Variable in class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
seekColfams - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
seekColumnFamilies - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
seekColumnFamiliesInclusive - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
seekRange - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
send_applyUpdates(TInfo, long, TKeyExtent, List<TMutation>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_authenticate(TInfo, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_authenticateUser(TInfo, TCredentials, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_beginFateOperation(TInfo, TCredentials) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
send_bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_checkClass(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_checkTableClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_chop(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_closeConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_closeMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_closeScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_closeUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_continueMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_continueScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_dropLocalUser(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
send_fails() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
send_fastHalt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_finishFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
send_flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_flushTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getActiveScans(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_getDiskUsage(Set<String>, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_getHistoricalStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getInstanceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_getMasterStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_getNamespaceConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_getRootTabletLocation() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_getStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
send_getTableConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_getTabletServerStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getTabletStats(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getUserAuthorizations(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_getZooKeepers() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_grantNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_grantSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_grantTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_halt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_hasNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_hasSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_hasTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_initiateFlush(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_invalidateConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_isActive(TInfo, long) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_listLocalUsers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_loadTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_ping(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_removeLogs(TInfo, TCredentials, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_removeNamespaceProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_removeSystemProperty(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_removeTableProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_reportSplitExtent(TInfo, TCredentials, String, TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_revokeNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_revokeSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_revokeTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_setMasterGoalState(TInfo, TCredentials, MasterGoalState) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_setNamespaceProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_setSystemProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_setTableProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_shutdown(TInfo, TCredentials, boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_shutdownTabletServer(TInfo, TCredentials, String, boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_startUpdate(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_success() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
send_throwsError() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
send_unloadTablet(TInfo, TCredentials, String, TKeyExtent, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_update(TInfo, TCredentials, TKeyExtent, TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_waitForFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
send_waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
SEPARATOR_CHAR - Static variable in class org.apache.accumulo.core.util.ServerServices
 
SequenceFileIterator - Class in org.apache.accumulo.core.iterators.system
 
SequenceFileIterator(SequenceFile.Reader, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
serialize() - Method in class org.apache.accumulo.core.client.ClientConfiguration
 
serialize(AuthenticationToken) - Static method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
A convenience method to serialize tokens.
serialize() - Method in class org.apache.accumulo.core.security.Authorizations
Returns a serialized form of these authorizations.
serialize() - Method in class org.apache.accumulo.core.security.Credentials
Converts the current object to a serialized form.
serializeColumns(Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
 
serializeColumns(Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
server - Variable in class org.apache.accumulo.core.master.thrift.DeadServer
 
server - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
ServerClient - Class in org.apache.accumulo.core.client.impl
 
ServerClient() - Constructor for class org.apache.accumulo.core.client.impl.ServerClient
 
ServerConfigurationUtil - Class in org.apache.accumulo.core.client.impl
All client side code that needs a server side configuration object should obtain it from here.
ServerConfigurationUtil() - Constructor for class org.apache.accumulo.core.client.impl.ServerConfigurationUtil
 
serverName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
serverName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
ServerServices - Class in org.apache.accumulo.core.util
 
ServerServices(String) - Constructor for class org.apache.accumulo.core.util.ServerServices
 
ServerServices(String, ServerServices.Service) - Constructor for class org.apache.accumulo.core.util.ServerServices
 
ServerServices.Service - Enum in org.apache.accumulo.core.util
 
serverSideIteratorList - Variable in class org.apache.accumulo.core.client.impl.ScannerOptions
 
serverSideIteratorOptions - Variable in class org.apache.accumulo.core.client.impl.ScannerOptions
 
serversShuttingDown - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
serversWaitedForWrites - Static variable in class org.apache.accumulo.core.client.impl.ThriftScanner
 
SERVICE_SEPARATOR - Static variable in class org.apache.accumulo.core.util.ServerServices
 
sessID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
sessID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
sessID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
sessionExpired() - Method in interface org.apache.accumulo.core.conf.ConfigurationObserver
 
sessionId - Variable in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
set(Property, String) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
set(String, String) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
set(Property, String) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
method here to support testing, do not call
set(String, String) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
method here to support testing, do not call
set(Key) - Method in class org.apache.accumulo.core.data.Key
Sets this key's row, column family, column qualifier, column visibility, timestamp, and delete marker to be the same as another key's.
set(byte[]) - Method in class org.apache.accumulo.core.data.Value
 
set(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
set(byte[], int, int) - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
set(ByteSequence) - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
setAccumuloConfigs(Job) - Method in class org.apache.accumulo.core.cli.ClientOnDefaultTable
 
setAccumuloConfigs(Job) - Method in class org.apache.accumulo.core.cli.ClientOnRequiredTable
 
setAccumuloConfigs(Job) - Method in class org.apache.accumulo.core.cli.ClientOpts
 
setAdvertiseViaMulticastDNS(boolean) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
setAge(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setAge(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setAgeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setAgeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setAlgorithmName(String) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the name of the symmetric algorithm to use for an encryption stream.
setAllOptions(Map<String, String>) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the overall set of options for the CryptoModule.
setApplication(String) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
setArguments(List<ByteBuffer>) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setArgumentsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setArray(byte[], int, int) - Method in class org.apache.accumulo.core.util.MutableByteSequence
 
setAuthorizationFailures(Map<TKeyExtent, SecurityErrorCode>) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setAuthorizationFailuresIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setAuthorizations(Authorizations) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
A set of authorization labels that will be checked against the column visibility of each key in order to filter data.
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setAuthorizations(IteratorSetting, Authorizations) - Static method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Configure authorizations used for post transformation filtering.
setAuthorizations(IteratorSetting, Authorizations) - Static method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setAuths(Authorizations) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
SetAuthsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
SetAuthsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.SetAuthsCommand
 
setAutoAdjustRanges(JobConf, boolean) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Controls the automatic adjustment of ranges for this job.
setAutoAdjustRanges(Job, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Controls the automatic adjustment of ranges for this job.
setAutoAdjustRanges(boolean) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Controls the automatic adjustment of ranges for this job.
setAutoAdjustRanges(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Controls the automatic adjustment of ranges for this job.
setAutoAdjustRanges(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setAutoClean(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setAutoCleanIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setBadTServers(Map<String, Byte>) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setBadTServersIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setBatch(Map<TKeyExtent, List<TRange>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setBatchIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setBatchSize(int) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
setBatchSize(int) - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
setBatchSize(int) - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
setBatchSize(int) - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
setBatchSize(int) - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
setBatchSize(int) - Method in interface org.apache.accumulo.core.client.Scanner
Sets the number of Key/Value pairs that will be fetched at a time from a tablet server.
setBatchSize(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setBatchSizeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setBatchWriterOptions(JobConf, BatchWriterConfig) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Sets the configuration for for the job's BatchWriter instances.
setBatchWriterOptions(Job, BatchWriterConfig) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Sets the configuration for for the job's BatchWriter instances.
setBatchWriterOptions(Class<?>, Configuration, BatchWriterConfig) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
Sets the configuration for for the job's BatchWriter instances.
setBatchWriterOptions(Class<?>, Configuration, BatchWriterConfig) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setBlockStreamSize(int) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the size of the buffering stream that sits above the cipher stream
setCandidates(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setCandidatesIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setCaseSensitive(boolean) - Method in class org.apache.accumulo.core.util.shell.Token
 
setCf(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setCf(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setCfIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setCipher(Cipher) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the initialized cipher object.
setClassName(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setClassName(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setClassName(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setClassName(String) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setClient(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setClientAuth(boolean) - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
setClientIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setCloseUnderylingStreamAfterCryptoStreamClose(boolean) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the flag that indicates whether or not to close the underlying stream when the cipher stream is closed.
setCmid(long) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
setCmidIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
setCode(SecurityErrorCode) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
setCodeIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
setColFamily(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColFamily(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColFamilyIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColfs(IteratorSetting, String, String) - Static method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
A convenience method for setting the index column family and document column family prefix.
setColQualifier(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColQualifier(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColQualifierIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColumnFamilies(IteratorSetting, Text[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
Encode the columns to be used when iterating.
setColumnFamilies(IteratorSetting, Text[], boolean[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
Encode columns and NOT flags indicating which columns should be negated (docIDs will be excluded if matching negated columns, instead of included).
setColumnFamily(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnFamily(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnFamilyIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnQualifier(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnQualifier(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnQualifierIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumns(IteratorSetting, List<IteratorSetting.Column>) - Static method in class org.apache.accumulo.core.iterators.Combiner
A convenience method to set which columns a combiner should be applied to.
setColumns(List<TColumn>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setColumns(List<TColumn>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setColumns(List<TColumn>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setColumnsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setColumnsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setColumnsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setColumnVisibility(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnVisibility(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnVisibilityIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColVisibility(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColVisibility(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColVisibilityIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setCombineAllColumns(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.Combiner
A convenience method to set the "all columns" option on a Combiner.
setCompressionType(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
Sets the compression type to use for data blocks.
setCompressionType(Job, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
Sets the compression type to use for data blocks.
setCompressionType(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
Sets the compression type to use for data blocks.
setCompressionType(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setConditions(List<TCondition>) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
setConditionsIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
setConf(Configuration) - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
 
setConf(Configuration) - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
 
setConfiguration(AccumuloConfiguration) - Method in interface org.apache.accumulo.core.client.Instance
Deprecated.
since 1.6.0. This method makes very little sense in the context of the client API and never should have been exposed.
setConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.client.mock.MockInstance
Deprecated.
setConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
setConnectorInfo(JobConf, String, AuthenticationToken) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(JobConf, String, String) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(JobConf, String, AuthenticationToken) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(JobConf, String, String) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(Job, String, AuthenticationToken) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(Job, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(Job, String, AuthenticationToken) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(Job, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(Class<?>, Configuration, String, AuthenticationToken) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(Class<?>, Configuration, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Sets the connector information needed to communicate with Accumulo in this job.
setConnectorInfo(Class<?>, Configuration, String, AuthenticationToken) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setConsoleInputStream(InputStream) - Method in class org.apache.accumulo.core.client.mock.MockShell
 
setConsoleWriter(OutputStream) - Method in class org.apache.accumulo.core.client.mock.MockShell
 
setConsoleWriter(Writer) - Method in class org.apache.accumulo.core.client.mock.MockShell
Deprecated.
since 1.6.0; use the OutputStream version
setConstrainClass(String) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setConstrainClassIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setContents(T) - Method in class org.apache.accumulo.core.util.BinaryTree
 
setCount(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setCountIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setCq(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setCq(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setCqIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setCreateTables(JobConf, boolean) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Sets the directive to create new tables, as necessary.
setCreateTables(Job, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Sets the directive to create new tables, as necessary.
setCreateTables(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
Sets the directive to create new tables, as necessary.
setCreateTables(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setCurrent(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setCurrentIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setCurrentLog(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setCurrentLogIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setCurrentTime(IteratorSetting, Long) - Static method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
A convenience method for setting the current time (from which to measure the age off threshold).
setCv(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setCv(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setCve(ConstraintViolationException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
setCveIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
setCvIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setData(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setData(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setDataBlockSize(JobConf, long) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
Sets the size for data blocks within each file.
Data blocks are a span of key/value pairs stored in the file that are compressed and indexed as a group.
setDataBlockSize(Job, long) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
Sets the size for data blocks within each file.
Data blocks are a span of key/value pairs stored in the file that are compressed and indexed as a group.
setDataBlockSize(Class<?>, Configuration, long) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
Sets the size for data blocks within each file.
Data blocks are a span of key/value pairs stored in the file that are compressed and indexed as a group.
setDataBlockSize(Class<?>, Configuration, long) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setDataCacheHits(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setDataCacheHitsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setDataCacheRequest(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setDataCacheRequestIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setDataIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setDeadTabletServers(List<DeadServer>) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setDeadTabletServersIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setDebugging(boolean) - Static method in class org.apache.accumulo.core.util.shell.Shell
 
setDefaultTableName(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Sets the default table name to use if one emits a null in place of a table name for a given mutation.
setDefaultTableName(Job, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Sets the default table name to use if one emits a null in place of a table name for a given mutation.
setDefaultTableName(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
Sets the default table name to use if one emits a null in place of a table name for a given mutation.
setDefaultTableName(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setDeleted(boolean) - Method in class org.apache.accumulo.core.data.Key
 
setDeleted(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setDeletedIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setDescription(String) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setDescription(String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
setDescriptionIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setDocColfPrefix(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
A convenience method for setting the document column family prefix.
setElapsed(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setElapsedIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setEncoder(TypedValueCombiner.Encoder<V>) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Sets the Encoder<V> used to translate Values to V and back.
setEncoder(String) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Instantiates and sets the Encoder<V> used to translate Values to V and back.
setEncoding(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.RegExFilter
Set the encoding string to use when interpreting characters
setEncodingType(IteratorSetting, LongCombiner.Type) - Static method in class org.apache.accumulo.core.iterators.LongCombiner
A convenience method for setting the long encoding type.
setEncodingType(IteratorSetting, Class<? extends TypedValueCombiner.Encoder<Long>>) - Static method in class org.apache.accumulo.core.iterators.LongCombiner
A convenience method for setting the long encoding type.
setEncodingType(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.LongCombiner
A convenience method for setting the long encoding type.
setEncodingType(IteratorSetting, SummingArrayCombiner.Type) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
A convenience method for setting the encoding type.
setEncodingType(IteratorSetting, Class<? extends TypedValueCombiner.Encoder<List<Long>>>) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
A convenience method for setting the encoding type.
setEncodingType(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
A convenience method for setting the encoding type.
setEncryptedInputStream(InputStream) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the encrypted input stream to wrap for decryption.
setEncryptedKey(byte[]) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the encrypted version of the plaintext key (CryptoModuleParameters.getPlaintextKey()).
setEncryptedOutputStream(OutputStream) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the encrypted output stream.
setEncryptionMode(String) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the name of the encryption mode to use for an encryption stream.
setEnd(IteratorSetting, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the end timestamp accepted by the timestamp filter.
setEnd(IteratorSetting, long, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the end timestamp accepted by the timestamp filter.
setEndRow(Text) - Method in class org.apache.accumulo.core.data.KeyExtent
Sets this extent's end row
setEndRow(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setEndRow(byte[]) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setEndRow(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setEndRow(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setEntries(int) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setEntriesIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setEntriesRead(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setEntriesReadIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setEntriesWritten(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setEntriesWrittenIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setErrorDir(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setErrorDirIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setErrors(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setErrorsIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setEstimatedSize(long) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
setEstimatedSizeIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
setEx(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
setExIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
setExit(boolean) - Method in class org.apache.accumulo.core.util.shell.Shell
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setExtent(TKeyExtent) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setExtent(TKeyExtent) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setExtentIsSet(boolean) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setExtentIsSet(boolean) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
setFail(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setFailedExtents(Map<TKeyExtent, Long>) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setFailedExtentsIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setFailIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setFailures(Map<TKeyExtent, List<TRange>>) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setFailuresIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setFetchedColumns(Collection<Pair<Text, Text>>) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setFetchedColumns(Set<Pair<Text, Text>>) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setFieldValue(ClientService.authenticate_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
setFieldValue(ClientService.authenticate_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
setFieldValue(ClientService.authenticateUser_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setFieldValue(ClientService.authenticateUser_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
setFieldValue(ClientService.bulkImportFiles_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setFieldValue(ClientService.bulkImportFiles_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
setFieldValue(ClientService.changeAuthorizations_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setFieldValue(ClientService.changeAuthorizations_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
setFieldValue(ClientService.changeLocalUserPassword_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setFieldValue(ClientService.changeLocalUserPassword_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
setFieldValue(ClientService.checkClass_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setFieldValue(ClientService.checkClass_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
setFieldValue(ClientService.checkNamespaceClass_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setFieldValue(ClientService.checkNamespaceClass_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
setFieldValue(ClientService.checkTableClass_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setFieldValue(ClientService.checkTableClass_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
setFieldValue(ClientService.createLocalUser_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setFieldValue(ClientService.createLocalUser_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
setFieldValue(ClientService.dropLocalUser_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
setFieldValue(ClientService.dropLocalUser_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
setFieldValue(ClientService.getConfiguration_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
setFieldValue(ClientService.getConfiguration_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
setFieldValue(ClientService.getDiskUsage_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
setFieldValue(ClientService.getDiskUsage_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
setFieldValue(ClientService.getInstanceId_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
setFieldValue(ClientService.getInstanceId_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
setFieldValue(ClientService.getNamespaceConfiguration_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
setFieldValue(ClientService.getNamespaceConfiguration_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
setFieldValue(ClientService.getRootTabletLocation_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
setFieldValue(ClientService.getRootTabletLocation_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
setFieldValue(ClientService.getTableConfiguration_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
setFieldValue(ClientService.getTableConfiguration_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
setFieldValue(ClientService.getUserAuthorizations_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setFieldValue(ClientService.getUserAuthorizations_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
setFieldValue(ClientService.getZooKeepers_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
setFieldValue(ClientService.getZooKeepers_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
setFieldValue(ClientService.grantNamespacePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setFieldValue(ClientService.grantNamespacePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
setFieldValue(ClientService.grantSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setFieldValue(ClientService.grantSystemPermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
setFieldValue(ClientService.grantTablePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setFieldValue(ClientService.grantTablePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
setFieldValue(ClientService.hasNamespacePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setFieldValue(ClientService.hasNamespacePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
setFieldValue(ClientService.hasSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setFieldValue(ClientService.hasSystemPermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
setFieldValue(ClientService.hasTablePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setFieldValue(ClientService.hasTablePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setFieldValue(ClientService.isActive_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
setFieldValue(ClientService.isActive_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
setFieldValue(ClientService.listLocalUsers_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
setFieldValue(ClientService.listLocalUsers_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
setFieldValue(ClientService.ping_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
setFieldValue(ClientService.ping_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
setFieldValue(ClientService.revokeNamespacePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setFieldValue(ClientService.revokeNamespacePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
setFieldValue(ClientService.revokeSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setFieldValue(ClientService.revokeSystemPermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
setFieldValue(ClientService.revokeTablePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setFieldValue(ClientService.revokeTablePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
setFieldValue(TDiskUsage._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
setFieldValue(ThriftSecurityException._Fields, Object) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
setFieldValue(ThriftTableOperationException._Fields, Object) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setFieldValue(ThriftTest.fails_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
setFieldValue(ThriftTest.fails_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
setFieldValue(ThriftTest.success_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
setFieldValue(ThriftTest.success_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
setFieldValue(ThriftTest.throwsError_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
setFieldValue(ThriftTest.throwsError_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
setFieldValue(InitialMultiScan._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
setFieldValue(InitialScan._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
setFieldValue(IterInfo._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setFieldValue(MapFileInfo._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
setFieldValue(MultiScanResult._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setFieldValue(ScanResult._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
setFieldValue(TCMResult._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
setFieldValue(TColumn._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setFieldValue(TCondition._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setFieldValue(TConditionalMutation._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
setFieldValue(TConditionalSession._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
setFieldValue(TConstraintViolationSummary._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setFieldValue(TKey._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setFieldValue(TKeyExtent._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setFieldValue(TKeyValue._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
setFieldValue(TMutation._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setFieldValue(TRange._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setFieldValue(UpdateErrors._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setFieldValue(GcCycleStats._Fields, Object) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setFieldValue(GCMonitorService.getStatus_args._Fields, Object) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setFieldValue(GCMonitorService.getStatus_result._Fields, Object) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setFieldValue(GCStatus._Fields, Object) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setFieldValue(Compacting._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
setFieldValue(DeadServer._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
setFieldValue(FateService.beginFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
setFieldValue(FateService.beginFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
setFieldValue(FateService.executeFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setFieldValue(FateService.executeFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
setFieldValue(FateService.finishFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
setFieldValue(FateService.finishFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
setFieldValue(FateService.waitForFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
setFieldValue(FateService.waitForFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
setFieldValue(MasterClientService.getMasterStats_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
setFieldValue(MasterClientService.getMasterStats_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
setFieldValue(MasterClientService.initiateFlush_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
setFieldValue(MasterClientService.initiateFlush_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
setFieldValue(MasterClientService.removeNamespaceProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setFieldValue(MasterClientService.removeNamespaceProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
setFieldValue(MasterClientService.removeSystemProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setFieldValue(MasterClientService.removeSystemProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
setFieldValue(MasterClientService.removeTableProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setFieldValue(MasterClientService.removeTableProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
setFieldValue(MasterClientService.reportSplitExtent_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setFieldValue(MasterClientService.reportTabletStatus_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setFieldValue(MasterClientService.setMasterGoalState_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
setFieldValue(MasterClientService.setMasterGoalState_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
setFieldValue(MasterClientService.setNamespaceProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setFieldValue(MasterClientService.setNamespaceProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
setFieldValue(MasterClientService.setSystemProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setFieldValue(MasterClientService.setSystemProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
setFieldValue(MasterClientService.setTableProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setFieldValue(MasterClientService.setTableProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
setFieldValue(MasterClientService.shutdown_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
setFieldValue(MasterClientService.shutdown_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
setFieldValue(MasterClientService.shutdownTabletServer_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setFieldValue(MasterClientService.shutdownTabletServer_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
setFieldValue(MasterClientService.waitForFlush_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setFieldValue(MasterClientService.waitForFlush_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
setFieldValue(MasterMonitorInfo._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setFieldValue(RecoveryException._Fields, Object) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
setFieldValue(RecoveryStatus._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setFieldValue(TableInfo._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setFieldValue(TabletServerStatus._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setFieldValue(TabletSplit._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
setFieldValue(TCredentials._Fields, Object) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setFieldValue(ActionStats._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setFieldValue(ActiveCompaction._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setFieldValue(ActiveScan._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setFieldValue(ConstraintViolationException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
setFieldValue(IteratorConfig._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
setFieldValue(NoSuchScanIDException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
setFieldValue(NotServingTabletException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
setFieldValue(TabletClientService.applyUpdates_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setFieldValue(TabletClientService.bulkImport_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setFieldValue(TabletClientService.bulkImport_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
setFieldValue(TabletClientService.chop_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setFieldValue(TabletClientService.closeConditionalUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
setFieldValue(TabletClientService.closeMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
setFieldValue(TabletClientService.closeMultiScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
setFieldValue(TabletClientService.closeScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
setFieldValue(TabletClientService.closeUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
setFieldValue(TabletClientService.closeUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
setFieldValue(TabletClientService.compact_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setFieldValue(TabletClientService.conditionalUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setFieldValue(TabletClientService.conditionalUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
setFieldValue(TabletClientService.continueMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
setFieldValue(TabletClientService.continueMultiScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
setFieldValue(TabletClientService.continueScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
setFieldValue(TabletClientService.continueScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setFieldValue(TabletClientService.fastHalt_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
setFieldValue(TabletClientService.flush_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setFieldValue(TabletClientService.flushTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setFieldValue(TabletClientService.getActiveCompactions_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
setFieldValue(TabletClientService.getActiveCompactions_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
setFieldValue(TabletClientService.getActiveScans_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
setFieldValue(TabletClientService.getActiveScans_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
setFieldValue(TabletClientService.getHistoricalStats_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
setFieldValue(TabletClientService.getHistoricalStats_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
setFieldValue(TabletClientService.getTabletServerStatus_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
setFieldValue(TabletClientService.getTabletServerStatus_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
setFieldValue(TabletClientService.getTabletStats_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
setFieldValue(TabletClientService.getTabletStats_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
setFieldValue(TabletClientService.halt_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
setFieldValue(TabletClientService.halt_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
setFieldValue(TabletClientService.invalidateConditionalUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
setFieldValue(TabletClientService.invalidateConditionalUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
setFieldValue(TabletClientService.loadTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setFieldValue(TabletClientService.removeLogs_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
setFieldValue(TabletClientService.splitTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setFieldValue(TabletClientService.splitTablet_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
setFieldValue(TabletClientService.startConditionalUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setFieldValue(TabletClientService.startConditionalUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
setFieldValue(TabletClientService.startMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setFieldValue(TabletClientService.startMultiScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
setFieldValue(TabletClientService.startScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setFieldValue(TabletClientService.startScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setFieldValue(TabletClientService.startUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
setFieldValue(TabletClientService.startUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
setFieldValue(TabletClientService.unloadTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setFieldValue(TabletClientService.update_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setFieldValue(TabletClientService.update_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
setFieldValue(TabletStats._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setFieldValue(TIteratorSetting._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setFieldValue(TooManyFilesException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
setFileBlockSize(JobConf, long) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
Sets the size for file blocks in the file system; file blocks are managed, and replicated, by the underlying file system.
setFileBlockSize(Job, long) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
Sets the size for file blocks in the file system; file blocks are managed, and replicated, by the underlying file system.
setFileBlockSize(Class<?>, Configuration, long) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
Sets the size for file blocks in the file system; file blocks are managed, and replicated, by the underlying file system.
setFileBlockSize(Class<?>, Configuration, long) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setFilenames(List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
setFilenamesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
setFiles(List<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setFiles(Map<TKeyExtent, Map<String, MapFileInfo>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setFilesIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setFilesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setFinished(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setFinishedIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setFlushID(long) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setFlushIDIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setForce(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setForceIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setFullScans(List<TKeyExtent>) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setFullScansIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setGoalState(MasterGoalState) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setGoalStateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
SetGroupsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
SetGroupsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.SetGroupsCommand
 
setHasTimestamp(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setHasTimestampIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setHoldTime(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setHoldTimeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setId(long) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
setIdleTime(long) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
Set the time after which idle connections should be closed
setIdleTime(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setIdleTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setIndex(Object) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
setIndex(Object) - Method in interface org.apache.accumulo.core.file.blockfile.cache.CacheEntry
 
setIndexBlockSize(JobConf, long) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
Sets the size for index blocks within each file; smaller blocks means a deeper index hierarchy within the file, while larger blocks mean a more shallow index hierarchy within the file.
setIndexBlockSize(Job, long) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
Sets the size for index blocks within each file; smaller blocks means a deeper index hierarchy within the file, while larger blocks mean a more shallow index hierarchy within the file.
setIndexBlockSize(Class<?>, Configuration, long) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
Sets the size for index blocks within each file; smaller blocks means a deeper index hierarchy within the file, while larger blocks mean a more shallow index hierarchy within the file.
setIndexBlockSize(Class<?>, Configuration, long) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setIndexCacheHits(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setIndexCacheHitsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setIndexCacheRequest(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setIndexCacheRequestIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setIndexColf(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
A convenience method for setting the index column family.
setInfiniteStartKey(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setInfiniteStartKeyIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setInfiniteStopKey(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setInfiniteStopKeyIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setIngestByteRate(double) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setIngestByteRateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setIngestRate(double) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setIngestRate(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setIngestRateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setIngestRateIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setInitializationVector(byte[]) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the initialization vector to use for this crypto module.
setInputFiles(List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setInputFilesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setInputTableConfigs(JobConf, Map<String, InputTableConfig>) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloMultiTableInputFormat
Sets the InputTableConfig objects on the given Hadoop configuration
setInputTableConfigs(Job, Map<String, InputTableConfig>) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
Sets the InputTableConfig objects on the given Hadoop configuration
setInputTableConfigs(Class<?>, Configuration, Map<String, InputTableConfig>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Sets configurations for multiple tables at a time.
setInputTableName(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Sets the name of the input table, over which this job will scan.
setInputTableName(Job, String) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Sets the name of the input table, over which this job will scan.
setInputTableName(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Sets the name of the input table, over which this job will scan.
setInputTableName(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setInstance(ShellOptionsJC) - Method in class org.apache.accumulo.core.client.mock.MockShell
 
setInstance(CommandLine) - Method in class org.apache.accumulo.core.client.mock.MockShell
Deprecated.
since 1.6.0; use ShellOptionsJC version
setInstance(Configuration) - Static method in class org.apache.accumulo.core.util.CachedConfiguration
 
setInstance(ShellOptionsJC) - Method in class org.apache.accumulo.core.util.shell.Shell
Sets the instance used by the shell based on the given options.
setInstanceId(String) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setInstanceIdIsSet(boolean) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setInstanceName(String) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setInterfaceMatch(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setInterfaceMatch(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setInterfaceMatch(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setInterfaceMatchIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setInterfaceMatchIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setInterfaceMatchIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
setInterruptFlag(AtomicBoolean) - Method in interface org.apache.accumulo.core.iterators.system.InterruptibleIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
 
setInterruptFlag(AtomicBoolean) - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
setInUse(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setInUseIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setIsolated(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setIsolatedIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setIsolatedScan(Boolean) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setIteratorClass(String) - Method in class org.apache.accumulo.core.client.IteratorSetting
Set the name of the class that implements the iterator.
setIteratorClass(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setIteratorClassIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setIterators(List<IteratorSetting>) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Set iterators on to be used in the query.
setIterators(List<IteratorSetting>) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setIterators(IteratorSetting...) - Method in class org.apache.accumulo.core.data.Condition
Set iterators to use when reading the columns value.
setIterators(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setIterators(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setIterators(List<TIteratorSetting>) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
setIteratorsIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setIteratorsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
SetIterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
SetIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.SetIterCommand
 
setIterName(String) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setIterNameIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setKey(TKey) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
setKeyEncryptionStrategyClass(String) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the class name of the key encryption strategy class.
setKeyExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setKeyExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setKeyExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setKeyExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setKeyIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
setKeyLength(int) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the length of the secret key that will be used to encrypt and decrypt bytes.
setKeyStoreFromConf(AccumuloConfiguration) - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
setLast(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setLastContact(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLastContactIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLastIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setLastLog(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setLastLogIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setLastStatus(long) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
setLastStatusIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
setLeft(BinaryTree<T>) - Method in class org.apache.accumulo.core.util.BinaryTree
 
setLength(int) - Method in class org.apache.accumulo.core.util.MutableByteSequence
 
setLocalIterators(JobConf, boolean) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Controls the use of the ClientSideIteratorScanner in this job.
setLocalIterators(Job, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Controls the use of the ClientSideIteratorScanner in this job.
setLocalIterators(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Controls the use of the ClientSideIteratorScanner in this job.
setLocalIterators(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setLocalityGroup(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setLocalityGroupIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setLocalityGroups(String, Map<String, Set<Text>>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Sets a table's locality groups.
setLocalityGroups(String, Map<String, Set<Text>>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Sets a tables locality groups.
setLocalityGroups(Map<String, Set<Text>>) - Method in class org.apache.accumulo.core.client.mock.MockTable
 
setLocationInfo(boolean) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
setLocations(String[]) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setLogErrorsToConsole() - Method in class org.apache.accumulo.core.util.shell.Shell
 
setLogLevel(JobConf, Level) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Sets the log level for this job.
setLogLevel(JobConf, Level) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Sets the log level for this job.
setLogLevel(Job, Level) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Sets the log level for this job.
setLogLevel(Job, Level) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Sets the log level for this job.
setLogLevel(Class<?>, Configuration, Level) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Sets the log level for this job.
setLogLevel(Class<?>, Configuration, Level) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setLogLevel(Level) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setLogSorts(List<RecoveryStatus>) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLogSortsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLookups(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLookupsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLossyness(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.TypedValueCombiner
A convenience method to set the "lossy" option on a TypedValueCombiner.
setMajors(Compacting) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setMajors(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMajorsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setMajorsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMasterGoalState(TInfo, TCredentials, MasterGoalState, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
setMasterGoalState(TInfo, TCredentials, MasterGoalState, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
setMasterGoalState(TInfo, TCredentials, MasterGoalState) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
setMasterGoalState(TInfo, TCredentials, MasterGoalState) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
setMaxBufferSize(IteratorSetting, long) - Static method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Configure the maximum amount of memory that can be used for transformation.
setMaxColumns(IteratorSetting, int) - Static method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
A convenience method for setting the maximum number of columns to keep.
setMaxLatency(long, TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Sets the maximum amount of time to hold the data in memory before flushing it to servers.
For no maximum, set to zero, or Long.MAX_VALUE with TimeUnit.MILLISECONDS.
setMaxLoops(long) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setMaxLoopsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setMaxMemory(long) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Sets the maximum memory to batch before writing.
setMaxSize(long) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
setMaxVersions(IteratorSetting, int) - Static method in class org.apache.accumulo.core.iterators.user.VersioningIterator
Encode the maximum number of versions to return onto the ScanIterator
setMaxWriteThreads(int) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Sets the maximum number of threads to use for writing data to the tablet servers.
setMaxWriteThreads(int) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Sets the maximum number of threads to use for writing data to the tablet servers.
setMinors(Compacting) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setMinors(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMinorsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setMinorsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMockInstance(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Configures a MockInstance for this job.
setMockInstance(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Configures a MockInstance for this job.
setMockInstance(Job, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Configures a MockInstance for this job.
setMockInstance(Job, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Configures a MockInstance for this job.
setMockInstance(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Configures a MockInstance for this job.
setMockInstance(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setMockInstance(Boolean) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setMore(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setMore(boolean) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
setMoreIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setMoreIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
setMutation(TMutation) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
setMutation(TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setMutationIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
setMutationIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setMutations(List<TMutation>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setMutations(Map<TKeyExtent, List<TConditionalMutation>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setMutationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setMutationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setName(String) - Method in class org.apache.accumulo.core.client.IteratorSetting
Set the iterator's name.
setName(String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
setName(String) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setName(String) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setName(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setNamedOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
setNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setNameIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setNamespace(MockNamespace) - Method in class org.apache.accumulo.core.client.mock.MockTable
 
setNamespaceId(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setNamespaceIdIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setNamespaceName(String) - Method in class org.apache.accumulo.core.client.mock.MockTable
 
setNamespaceProperties(CommandLine, Shell, int, Map<String, String>, String, String) - Method in class org.apache.accumulo.core.util.shell.commands.SetIterCommand
 
setNamespaceProperty(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
setNamespaceProperty(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
setNamespaceProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
setNamespaceProperty(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
setNegate(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.Filter
A convenience method for setting the negation option on a filter.
setNewTablets(List<TKeyExtent>) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
setNewTabletsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
setNs(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
setNs(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setNs(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setNs(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setNs(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setNs(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setNste(NotServingTabletException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setNste(NotServingTabletException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
setNste(NotServingTabletException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setNste(NotServingTabletException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
setNsteIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setNsteIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
setNsteIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setNsteIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
setNum(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setNumberOfViolatingMutations(long) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setNumberOfViolatingMutationsIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setNumEntries(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setNumEntriesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setNumIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setNumScansBeforeSeek(IteratorSetting, int) - Static method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
convenience method to set the option to optimize the frequency of scans vs.
setNumSubBins(Job, int) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
Sets the number of random sub-bins per range
setNumSubBins(Job, int) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
Sets the number of random sub-bins per range
setOffline(Boolean) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setOfflineScan(boolean) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Enable reading offline tables.
setOfflineTableScan(JobConf, boolean) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Enable reading offline tables.
setOfflineTableScan(Job, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Enable reading offline tables.
setOfflineTableScan(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Enable reading offline tables.
setOfflineTableScan(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setOldTablet(TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
setOldTabletIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
setOnlineTablets(int) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setOnlineTabletsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setOp(TableOperation) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setOp(FateOperation) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setOpaqueKeyEncryptionKeyID(String) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets an opaque ID assocaited with the encrypted version of the plaintext key.
setOpid(long) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setOpid(long) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
setOpid(long) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
setOpidIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setOpidIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
setOpidIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
setOpIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setOpIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setOptions(ScannerOptions, ScannerOptions) - Static method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
setOptions(Map<String, String>) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setOptionsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setOsLoad(double) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setOsLoadIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setOutputFile(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setOutputFileIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setOverrideStreamsSecretKeyEncryptionStrategy(boolean) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the flag that indicates if the underlying stream's key encryption strategy should be overridden by the currently configured key encryption strategy.
setPadding(String) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the name of the padding type to use for an encryption stream.
setParent(BinaryTree<T>) - Method in class org.apache.accumulo.core.util.BinaryTree
 
setPartNextKey(TKey) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setPartNextKeyInclusive(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setPartNextKeyInclusiveIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setPartNextKeyIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setPartScan(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setPartScanIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setPassword(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setPassword(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
setPassword(CharBuffer) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setPlaintextInputStream(InputStream) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the plaintext input stream, which is nearly always a wrapped version of the output from CryptoModuleParameters.getEncryptedInputStream().
setPlaintextKey(byte[]) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the plaintext secret key that will be used to encrypt and decrypt bytes.
setPlaintextOutputStream(OutputStream) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the plaintext output stream to wrap for encryption.
setPlugin(CommandLine, Shell, String, String) - Method in class org.apache.accumulo.core.util.shell.commands.FormatterCommand
 
setPlugin(CommandLine, Shell, String, String) - Method in class org.apache.accumulo.core.util.shell.commands.ShellPluginConfigurationCommand
 
setPort(int) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
setPrevEndRow(Text) - Method in class org.apache.accumulo.core.data.KeyExtent
Sets the previous extent's end row
setPrevEndRow(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setPrevEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setPrevEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setPrevKey(Key) - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setPrincipal(String) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setPriority(int) - Method in class org.apache.accumulo.core.client.IteratorSetting
Set layer at which this iterator applies.
setPriority(int) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setPriority(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setPriorityIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setPriorityIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setProgress(double) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setProgressIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setProperties(Map<String, String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setPropertiesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setProperty(String, String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Sets an system property in zookeeper.
setProperty(String, String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Sets a property on a namespace which applies to all tables in the namespace.
setProperty(String, String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Sets a property on a table.
setProperty(ClientConfiguration.ClientProperty, String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Sets the value of property to value
setProperty(String, String) - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
setProperty(String, String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
setProperty(String, String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Sets a property on a table
setProperty(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setQueryByteRate(double) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setQueryByteRateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setQueryRate(double) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setQueryRate(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setQueryRateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setQueryRateIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setQueued(int) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
setQueuedIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
setQueueSumDev(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueTime(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setRandomNumberGenerator(String) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the name of the random number generator to use.
setRandomNumberGeneratorProvider(String) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the name of the random number generator provider to use.
setRange(Range) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
setRange(Range) - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
setRange(Range) - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
setRange(Range) - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
setRange(Range) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setRange(Range) - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
setRange(Range) - Method in interface org.apache.accumulo.core.client.Scanner
Sets the range of keys to scan over.
setRange(IteratorSetting, String, String) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the range of timestamps accepted by the timestamp filter.
setRange(IteratorSetting, String, boolean, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the range of timestamps accepted by the timestamp filter.
setRange(IteratorSetting, long, long) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the range of timestamps accepted by the timestamp filter.
setRange(IteratorSetting, long, boolean, long, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the range of timestamps accepted by the timestamp filter.
setRange(TRange) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setRangeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setRanges(Collection<Range>) - Method in interface org.apache.accumulo.core.client.BatchDeleter
Allows deleting multiple ranges efficiently.
setRanges(Collection<Range>) - Method in interface org.apache.accumulo.core.client.BatchScanner
Allows scanning over multiple ranges efficiently.
setRanges(Collection<Range>) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
 
setRanges(JobConf, Collection<Range>) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Sets the input ranges to scan for this job.
setRanges(Job, Collection<Range>) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Sets the input ranges to scan for the single input table associated with this job.
setRanges(List<Range>) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Sets the input ranges to scan for all tables associated with this job.
setRanges(Class<?>, Configuration, Collection<Range>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Sets the input ranges to scan on all input tables for this job.
setRanges(Class<?>, Configuration, Collection<Range>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setRanges(Collection<Range>) - Method in class org.apache.accumulo.core.client.mock.MockBatchScanner
 
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
 
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
setReadaheadThreshold(long) - Method in interface org.apache.accumulo.core.client.Scanner
Sets the number of batches of Key/Value pairs returned before the Scanner will begin to prefetch the next batch
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setReadaheadThresholdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setReason(CompactionReason) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setReasonIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setReconnectionDelay(int) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
setRecordParametersToStream(boolean) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Gets the flag that indicates whether or not the module should record its cryptographic parameters to the stream automatically, or rely on the calling code to do so.
setRecs(long) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setRecsInMemory(long) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setRecsInMemoryIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setRecsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setReduceOnFullCompactionOnly(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.Combiner
Combiners may not work correctly with deletes.
setRegexs(IteratorSetting, String, String, String, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.RegExFilter
Encode the terms to match against in the iterator.
setRegexs(IteratorSetting, String, String, String, String, boolean, boolean) - Static method in class org.apache.accumulo.core.iterators.user.RegExFilter
Encode the terms to match against in the iterator
setRemoteHost(String) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
 
setReplication(JobConf, int) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
Sets the file system replication factor for the resulting file, overriding the file system default.
setReplication(Job, int) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
Sets the file system replication factor for the resulting file, overriding the file system default.
setReplication(Class<?>, Configuration, int) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
Sets the file system replication factor for the resulting file, overriding the file system default.
setReplication(Class<?>, Configuration, int) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setResult(MultiScanResult) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
setResult(ScanResult) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
setResultIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
setResultIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
setResults(List<TKeyValue>) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setResults(List<TKeyValue>) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
setResultsIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
setResultsIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
setRight(BinaryTree<T>) - Method in class org.apache.accumulo.core.util.BinaryTree
 
setRow(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setRow(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setRow(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setRow(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setRowIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setRowIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setRunning(int) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
setRunningIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
setRuntime(int) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setRuntimeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setSave(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setSaveIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setScanAuthorizations(JobConf, Authorizations) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Sets the Authorizations used to scan.
setScanAuthorizations(Job, Authorizations) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Sets the Authorizations used to scan.
setScanAuthorizations(Class<?>, Configuration, Authorizations) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Sets the Authorizations used to scan.
setScanAuthorizations(Class<?>, Configuration, Authorizations) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setScanID(long) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
setScanID(long) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
setScanId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setScanID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
setScanID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
setScanID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
setScanID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
setScanIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
setScanIsolation(JobConf, boolean) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Controls the use of the IsolatedScanner in this job.
setScanIsolation(Job, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Controls the use of the IsolatedScanner in this job.
setScanIsolation(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Controls the use of the IsolatedScanner in this job.
setScanIsolation(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
SetScanIterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
SetScanIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.SetScanIterCommand
 
setScanRate(double) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setScanRateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setScans(Compacting) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setScansIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
setSecureRandom(SecureRandom) - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
Sets the initialized secure random object.
setServer(String) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
setServerIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
setServerName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setServerName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setServerNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setServerNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setServersShuttingDown(Set<String>) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setServersShuttingDownIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setSessID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
setSessID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setSessID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
setSessIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
setSessIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setSessIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
setSessionId(long) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
setSessionIdIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
setSetTime(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setSetTime(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setSetTimeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setSetTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
SetShellIterCommand - Class in org.apache.accumulo.core.util.shell.commands
 
SetShellIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.SetShellIterCommand
 
setSimulationMode(JobConf, boolean) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Sets the directive to use simulation mode for this job.
setSimulationMode(Job, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Sets the directive to use simulation mode for this job.
setSimulationMode(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
Sets the directive to use simulation mode for this job.
setSimulationMode(Class<?>, Configuration, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setSlice(IteratorSetting, String, String) - Static method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
setSlice(IteratorSetting, String, boolean, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
setSource(Scanner) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
Sets the source Scanner.
setSource(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
setSplit(TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setSplitCreationTime(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitCreationTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitFile(Job, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
Sets the hdfs file name to use, containing a newline separated list of Base64 encoded split points that represent ranges for partitioning
setSplitFile(Job, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
Sets the hdfs file name to use, containing a newline separated list of Base64 encoded split points that represent ranges for partitioning
setSplitIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setSplitPoint(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setSplitPoint(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setSplitPointIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setSplits(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSsiList(List<IterInfo>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setSsiList(List<IterInfo>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setSsiList(List<IterInfo>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setSsiList(List<IterInfo>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setSsiListIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setSsiListIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setSsiListIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setSsiListIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setSsio(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setSsio(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setSsio(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setSsio(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setSsioIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setSsioIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setSsioIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setSsioIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setStart(TKey) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setStart(IteratorSetting, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the start timestamp accepted by the timestamp filter.
setStart(IteratorSetting, long, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the start timestamp accepted by the timestamp filter.
setStarted(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setStartedIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setStartIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setStartKeyInclusive(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setStartKeyInclusiveIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setStartRow(byte[]) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setStartRow(ByteBuffer) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setStartRow(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setStartRow(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setStartRow(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setStartRow(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setStartRowIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setStartRowIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setStartRowIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setState(MasterGoalState) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
setState(MasterState) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setState(ScanState) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setStateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
setStateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setStateIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setStatus(TCMStatus) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
setStatus(String) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
setStatus(TabletLoadState) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setStatus(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setStop(TKey) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setStopIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setStopKeyInclusive(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setStopKeyInclusiveIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
setStopTabletServers(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
setStopTabletServersIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
setSuccess(List<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
setSuccess(List<TDiskUsage>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
setSuccess(List<ByteBuffer>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
setSuccess(Set<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
setSuccess(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSuccess(long) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
setSuccess(MasterMonitorInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
setSuccess(long) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
setSuccess(List<TKeyExtent>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
setSuccess(UpdateErrors) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
setSuccess(List<TCMResult>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
setSuccess(MultiScanResult) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
setSuccess(ScanResult) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setSuccess(List<ActiveCompaction>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
setSuccess(List<ActiveScan>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
setSuccess(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
setSuccess(TabletServerStatus) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
setSuccess(List<TabletStats>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
setSuccess(TConditionalSession) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
setSuccess(InitialMultiScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
setSuccess(InitialScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setSuccess(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
setSumDev(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setSymbols(List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setSymbolsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setSysPerm(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setSysPermIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setSystemProperty(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
setSystemProperty(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
setSystemProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
setSystemProperty(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
setTable(String) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
setTable(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setTable(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setTableId(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setTableId(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setTableId(String) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setTableId(String) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setTableId(Text) - Method in class org.apache.accumulo.core.data.KeyExtent
Sets the extents table id
setTableId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setTableId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setTableId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setTableId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
setTableID(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setTableIdIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
setTableIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setTableInfo(String) - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
setTableIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setTableMap(Map<String, TableInfo>) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setTableMap(Map<String, TableInfo>) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setTableMapIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setTableMapIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setTableName(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
setTableName(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setTableName(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setTableName(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setTableName(String) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setTableName(String) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
setTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setTableName(String) - Method in class org.apache.accumulo.core.util.shell.Shell
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setTableNameIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setTableProperties(CommandLine, Shell, int, Map<String, String>, String, String) - Method in class org.apache.accumulo.core.util.shell.commands.SetIterCommand
 
setTableProperties(CommandLine, Shell, int, Map<String, String>, String, String) - Method in class org.apache.accumulo.core.util.shell.commands.SetScanIterCommand
 
setTableProperties(CommandLine, Shell, int, Map<String, String>, String, String) - Method in class org.apache.accumulo.core.util.shell.commands.SetShellIterCommand
 
setTableProperty(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
setTableProperty(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
setTableProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
setTableProperty(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
setTables(Set<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
setTables(List<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
setTablesIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
setTablesIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
setTablet(TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setTabletIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setTablets(int) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setTabletServer(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setTabletServerIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setTabletsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setTblNspcPerm(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setTblNspcPermIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setTblPerm(byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setTblPermIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setTerm(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.GrepIterator
Encode the grep term as an option for a ScanIterator
setTid(long) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setTid(long) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
setTid(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setTime - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setTime(long) - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
setTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setTimeout(long, TimeUnit) - Method in interface org.apache.accumulo.core.client.BatchScanner
Sets a timeout threshold for a server to respond.
setTimeout(long, TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Sets the maximum amount of time an unresponsive server will be re-tried.
setTimeOut(int) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
Deprecated.
setTimeout(long, TimeUnit) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Sets the maximum amount of time an unresponsive server will be re-tried.
setTimeOut(int) - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
Deprecated.
setTimeOut(int) - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
Deprecated.
setTimeout(long, TimeUnit) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
setTimeOut(int) - Method in class org.apache.accumulo.core.client.IsolatedScanner
Deprecated.
setTimeOut(int) - Method in class org.apache.accumulo.core.client.mock.MockScanner
Deprecated.
setTimeOut(int) - Method in interface org.apache.accumulo.core.client.Scanner
setTimeout(long, TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
This setting determines how long a scanner will automatically retry when a failure occurs.
setTimestamp(long) - Method in class org.apache.accumulo.core.data.Condition
Sets the version for the column to check.
setTimestamp(long) - Method in class org.apache.accumulo.core.data.Key
 
setTimestamp(long) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setTimestampIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setTimeZone(TimeZone) - Method in class org.apache.accumulo.core.util.format.DateStringFormatter
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setTmfe(TooManyFilesException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setTmfe(TooManyFilesException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setTmfeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setTmfeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
setToAuth(TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setToAuthIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setToe(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
setToeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
setToken(AuthenticationToken) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setToken(String) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setToken(byte[]) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setToken(ByteBuffer) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setTokenClassName(String) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setTokenClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setTokenIsSet(boolean) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
setTrustStoreFromConf(AccumuloConfiguration) - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
setTs(long) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setTServerInfo(List<TabletServerStatus>) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setTServerInfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setTserverLock(String) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
setTserverLockIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
setTsIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setTtl(long) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
setTTL(IteratorSetting, Long) - Static method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
A convenience method for setting the age off threshold.
setTtlIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
setType(ConfigurationType) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
setType(TableOperationExceptionType) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setType(CompactionType) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setType(ScanType) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setTypeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
setTypeIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setTypeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setTypeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setUnassignedTablets(int) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setUnassignedTabletsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setUnnamedOptionDescriptions(List<String>) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
setUpdateID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setUpdateID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
setUpdateIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
setUpdateIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
setUpIterator(int, String, String, BatchScanner, CommandLine) - Method in class org.apache.accumulo.core.util.shell.commands.EGrepCommand
 
setUpIterator(int, String, String, BatchScanner, CommandLine) - Method in class org.apache.accumulo.core.util.shell.commands.GrepCommand
 
setupIterators(JobConf, Scanner, String, RangeInputSplit) - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
Configures the iterators on a scanner for the given table name.
setupIterators(JobConf, Scanner, String, RangeInputSplit) - Method in class org.apache.accumulo.core.client.mapred.InputFormatBase.RecordReaderBase
 
setupIterators(List<IteratorSetting>, Scanner) - Method in class org.apache.accumulo.core.client.mapred.InputFormatBase.RecordReaderBase
Apply the configured iterators to the scanner.
setupIterators(JobConf, Scanner) - Method in class org.apache.accumulo.core.client.mapred.InputFormatBase.RecordReaderBase
Deprecated.
setupIterators(TaskAttemptContext, Scanner, String, RangeInputSplit) - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Configures the iterators on a scanner for the given table name.
setupIterators(TaskAttemptContext, Scanner, String, RangeInputSplit) - Method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RecordReaderBase
Apply the configured iterators from the configuration to the scanner for the specified table name
setupIterators(TaskAttemptContext, Scanner) - Method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RecordReaderBase
Deprecated.
setupIterators(TaskAttemptContext, Scanner, RangeInputSplit) - Method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RecordReaderBase
Initialize a scanner over the given input split using this task attempt configuration.
setUsage(long) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
setUsageIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
setUseIsolatedScanners(boolean) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Controls the use of the IsolatedScanner in this job.
setUseJsse(boolean) - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
setUseLocalIterators(boolean) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Controls the use of the ClientSideIteratorScanner in this job.
setUser(String) - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
setUser(String) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
setUser(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setUserIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setUsesLocalIterators(Boolean) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
setVal(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setVal(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setValIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
setValue(CharSequence) - Method in class org.apache.accumulo.core.data.Condition
setValue(byte[]) - Method in class org.apache.accumulo.core.data.Condition
This method sets the expected value of a column.
setValue(Text) - Method in class org.apache.accumulo.core.data.Condition
setValue(ByteSequence) - Method in class org.apache.accumulo.core.data.Condition
setValue(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
setValue(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
setValue(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setValue(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setValue(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setValues(List<ByteBuffer>) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setValuesIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setViolationCode(short) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setViolationCodeIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setViolationDescription(String) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setViolationDescriptionIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setViolationSummaries(List<TConstraintViolationSummary>) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setViolationSummaries(List<TConstraintViolationSummary>) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
setViolationSummariesIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setViolationSummariesIsSet(boolean) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
setVisibility(ColumnVisibility) - Method in class org.apache.accumulo.core.data.Condition
Sets the visibility for the column to check.
setVisibilityCacheSize(Configuration, int) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Sets the valid visibility count for this job.
setWaitForWrites(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setWaitForWrites(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setWaitForWritesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setWaitForWritesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setWhy(String) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
setWhyIsSet(boolean) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
setWithCredentialProviders(String, String) - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
setZooKeeperInstance(JobConf, String, String) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
setZooKeeperInstance(JobConf, ClientConfiguration) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Configures a ZooKeeperInstance for this job.
setZooKeeperInstance(JobConf, String, String) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
setZooKeeperInstance(JobConf, ClientConfiguration) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Configures a ZooKeeperInstance for this job.
setZooKeeperInstance(Job, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
setZooKeeperInstance(Job, ClientConfiguration) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Configures a ZooKeeperInstance for this job.
setZooKeeperInstance(Job, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
setZooKeeperInstance(Job, ClientConfiguration) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Configures a ZooKeeperInstance for this job.
setZooKeeperInstance(Class<?>, Configuration, ClientConfiguration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
Configures a ZooKeeperInstance for this job.
setZooKeeperInstance(Class<?>, Configuration, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
setZooKeepers(String) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
ShardedTableDistributionFormatter - Class in org.apache.accumulo.core.util.format
Formats the rows in a METADATA table scan to show distribution of shards over servers per day.
ShardedTableDistributionFormatter() - Constructor for class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
 
Shell - Class in org.apache.accumulo.core.util.shell
A convenient console interface to perform basic accumulo functions Includes auto-complete, help, and quoted strings with escape sequences
Shell() - Constructor for class org.apache.accumulo.core.util.shell.Shell
 
Shell(ConsoleReader, PrintWriter) - Constructor for class org.apache.accumulo.core.util.shell.Shell
 
Shell.Command - Class in org.apache.accumulo.core.util.shell
The Command class represents a command to be run in the shell.
Shell.Command() - Constructor for class org.apache.accumulo.core.util.shell.Shell.Command
 
Shell.Command.CompletionSet - Enum in org.apache.accumulo.core.util.shell
 
Shell.PrintFile - Class in org.apache.accumulo.core.util.shell
 
Shell.PrintFile(String) - Constructor for class org.apache.accumulo.core.util.shell.Shell.PrintFile
 
Shell.PrintLine - Interface in org.apache.accumulo.core.util.shell
 
Shell.PrintShell - Class in org.apache.accumulo.core.util.shell
 
Shell.PrintShell(ConsoleReader) - Constructor for class org.apache.accumulo.core.util.shell.Shell.PrintShell
 
ShellCommandException - Exception in org.apache.accumulo.core.util.shell
 
ShellCommandException(ShellCommandException.ErrorCode) - Constructor for exception org.apache.accumulo.core.util.shell.ShellCommandException
 
ShellCommandException(ShellCommandException.ErrorCode, String) - Constructor for exception org.apache.accumulo.core.util.shell.ShellCommandException
 
ShellCommandException.ErrorCode - Enum in org.apache.accumulo.core.util.shell
 
ShellCompletor - Class in org.apache.accumulo.core.util.shell
 
ShellCompletor() - Constructor for class org.apache.accumulo.core.util.shell.ShellCompletor
 
ShellCompletor(Token) - Constructor for class org.apache.accumulo.core.util.shell.ShellCompletor
 
ShellCompletor(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Constructor for class org.apache.accumulo.core.util.shell.ShellCompletor
 
ShellExtension - Class in org.apache.accumulo.core.util.shell
 
ShellExtension() - Constructor for class org.apache.accumulo.core.util.shell.ShellExtension
 
ShellOptions - Class in org.apache.accumulo.core.util.shell
Abstract class to encompass the Options available on the Accumulo Shell
ShellOptions() - Constructor for class org.apache.accumulo.core.util.shell.ShellOptions
 
ShellOptionsJC - Class in org.apache.accumulo.core.util.shell
 
ShellOptionsJC() - Constructor for class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
ShellOptionsJC.PasswordConverter - Class in org.apache.accumulo.core.util.shell
 
ShellOptionsJC.PasswordConverter() - Constructor for class org.apache.accumulo.core.util.shell.ShellOptionsJC.PasswordConverter
 
ShellOptionsJC.TokenConverter - Class in org.apache.accumulo.core.util.shell
 
ShellOptionsJC.TokenConverter() - Constructor for class org.apache.accumulo.core.util.shell.ShellOptionsJC.TokenConverter
 
ShellPluginConfigurationCommand - Class in org.apache.accumulo.core.util.shell.commands
 
shouldAutoAdjustRanges() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Determines whether a configuration has auto-adjust ranges enabled.
shouldUseIsolatedScanners() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Determines whether a configuration has isolation enabled.
shouldUseLocalIterators() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Determines whether a configuration uses local iterators.
shutdown() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
shutdown() - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
Shutdown the cache.
shutdown() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
shutdown() - Method in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
 
shutdown(TInfo, TCredentials, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
shutdown(TInfo, TCredentials, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
shutdown(TInfo, TCredentials, boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
shutdown(TInfo, TCredentials, boolean) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
shutdown() - Method in class org.apache.accumulo.core.util.shell.Shell
 
shutdownNow() - Static method in class org.apache.accumulo.core.util.CleanUp
kills all threads created by internal Accumulo singleton resources.
shutdownTabletServer(TInfo, TCredentials, String, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
shutdownTabletServer(TInfo, TCredentials, String, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
shutdownTabletServer(TInfo, TCredentials, String, boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
shutdownTabletServer(TInfo, TCredentials, String, boolean) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
SimpleBlockCache - Class in org.apache.accumulo.core.file.blockfile.cache
Simple one RFile soft reference cache.
SimpleBlockCache() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
Constructor
SimpleThreadPool - Class in org.apache.accumulo.core.util
Create a simple thread pool using common parameters.
SimpleThreadPool(int, String) - Constructor for class org.apache.accumulo.core.util.SimpleThreadPool
 
SimpleThreadPool(int, String, BlockingQueue<Runnable>) - Constructor for class org.apache.accumulo.core.util.SimpleThreadPool
 
SiteConfiguration - Class in org.apache.accumulo.core.conf
A configuration drawn from an XML configuration file specified by the system property org.apache.accumulo.config.file, which points to the file as a resource.
siteFile - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
size() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
size() - Method in class org.apache.accumulo.core.data.Mutation
 
size() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get the size of this cache (number of cached blocks)
size() - Method in class org.apache.accumulo.core.file.blockfile.cache.SimpleBlockCache
 
size() - Method in class org.apache.accumulo.core.file.rfile.bcfile.ByteArray
 
size() - Method in interface org.apache.accumulo.core.file.rfile.bcfile.RawComparable
Get the size of the byte range in the byte array.
size() - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Get the size of the serialized Version object.
size() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
size() - Method in class org.apache.accumulo.core.security.Authorizations
Gets the size of this collection of authorizations.
size() - Method in class org.apache.accumulo.core.util.MapCounter
 
SizeConstants - Class in org.apache.accumulo.core.file.blockfile.cache
 
SizeConstants() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
 
SIZEOF_BOOLEAN - Static variable in class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
 
SIZEOF_BYTE - Static variable in class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
Size of byte in bytes
SIZEOF_CHAR - Static variable in class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
Size of char in bytes
SIZEOF_DOUBLE - Static variable in class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
Size of double in bytes
SIZEOF_FLOAT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
Size of float in bytes
SIZEOF_INT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
Size of int in bytes
SIZEOF_LONG - Static variable in class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
Size of long in bytes
SIZEOF_SHORT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.SizeConstants
Size of short in bytes
skip(long) - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
skip(long) - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
 
SkippingIterator - Class in org.apache.accumulo.core.iterators
Every call to SkippingIterator.next() and SkippingIterator.seek(Range, Collection, boolean) calls the parent's implementation and then calls the implementation's SkippingIterator.consume().
SkippingIterator() - Constructor for class org.apache.accumulo.core.iterators.SkippingIterator
 
sleep(long) - Static method in class org.apache.accumulo.core.util.UtilWaitThread
 
SleepCommand - Class in org.apache.accumulo.core.util.shell.commands
 
SleepCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.SleepCommand
 
sortAuthorizations(Authorizations) - Method in class org.apache.accumulo.core.util.shell.commands.GetAuthsCommand
 
sortByStart(Collection<RemoteSpan>) - Static method in class org.apache.accumulo.core.trace.TraceDump
 
sortedColFams - Variable in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
 
SortedKeyIterator - Class in org.apache.accumulo.core.iterators
 
SortedKeyIterator() - Constructor for class org.apache.accumulo.core.iterators.SortedKeyIterator
 
SortedKeyIterator(SortedKeyIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.SortedKeyIterator
 
SortedKeyValueIterator<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> - Interface in org.apache.accumulo.core.iterators
An iterator that supports iterating over key and value pairs.
SortedMapIterator - Class in org.apache.accumulo.core.iterators
A simple iterator over a Java SortedMap Note that this class is intended as an in-memory replacement for RFile$Reader, so its behavior reflects the same assumptions; namely, that this iterator is not responsible for respecting the columnFamilies passed into seek().
SortedMapIterator(SortedMap<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.SortedMapIterator
 
sourceIter - Variable in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
sources - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
SourceSwitchingIterator - Class in org.apache.accumulo.core.iterators.system
A SortedKeyValueIterator which presents a view over some section of data, regardless of whether or not it is backed by memory (InMemoryMap) or an RFile (InMemoryMap that was minor compacted to a file).
SourceSwitchingIterator(SourceSwitchingIterator.DataSource, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
SourceSwitchingIterator(SourceSwitchingIterator.DataSource) - Constructor for class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
SourceSwitchingIterator.DataSource - Interface in org.apache.accumulo.core.iterators.system
 
SpanTree - Class in org.apache.accumulo.core.trace
 
SpanTree() - Constructor for class org.apache.accumulo.core.trace.SpanTree
 
SpanTreeVisitor - Interface in org.apache.accumulo.core.trace
 
split(byte[]) - Static method in class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
Splits a byte array by 0x00
split - Variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
 
split - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
 
split - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
SPLIT_RATIO_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
A temporary field for splits to optimize certain operations
splitCreationTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
SplitLarge - Class in org.apache.accumulo.core.file.rfile
Split an RFile into large and small key/value files.
SplitLarge() - Constructor for class org.apache.accumulo.core.file.rfile.SplitLarge
 
splitPoint - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
splitRangeByTablets(String, Range, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
splitRangeByTablets(String, Range, int) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
splits - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
ssiList - Variable in class org.apache.accumulo.core.client.impl.CompressedIterators.IterConfig
 
ssiList - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
ssiList - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
ssiList - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
ssiList - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
ssio - Variable in class org.apache.accumulo.core.client.impl.CompressedIterators.IterConfig
 
ssio - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
ssio - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
ssio - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
ssio - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
SslConnectionParams - Class in org.apache.accumulo.core.util
 
sslEnabled - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
start(I, ClientService.authenticate_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
 
start(I, ClientService.authenticateUser_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
 
start(I, ClientService.bulkImportFiles_args, AsyncMethodCallback<List<String>>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
 
start(I, ClientService.changeAuthorizations_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
start(I, ClientService.changeLocalUserPassword_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
start(I, ClientService.checkClass_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
 
start(I, ClientService.checkNamespaceClass_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
start(I, ClientService.checkTableClass_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
 
start(I, ClientService.createLocalUser_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
 
start(I, ClientService.dropLocalUser_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
start(I, ClientService.getConfiguration_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
 
start(I, ClientService.getDiskUsage_args, AsyncMethodCallback<List<TDiskUsage>>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
start(I, ClientService.getInstanceId_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
 
start(I, ClientService.getNamespaceConfiguration_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
start(I, ClientService.getRootTabletLocation_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
start(I, ClientService.getTableConfiguration_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
start(I, ClientService.getUserAuthorizations_args, AsyncMethodCallback<List<ByteBuffer>>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
start(I, ClientService.getZooKeepers_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
start(I, ClientService.grantNamespacePermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
start(I, ClientService.grantSystemPermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
start(I, ClientService.grantTablePermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
start(I, ClientService.hasNamespacePermission_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
start(I, ClientService.hasSystemPermission_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
start(I, ClientService.hasTablePermission_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
start(I, ClientService.isActive_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
 
start(I, ClientService.listLocalUsers_args, AsyncMethodCallback<Set<String>>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
start(I, ClientService.ping_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
 
start(I, ClientService.revokeNamespacePermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
start(I, ClientService.revokeSystemPermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
start(I, ClientService.revokeTablePermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
start(I, ThriftTest.fails_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
 
start(I, ThriftTest.success_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.success
 
start(I, ThriftTest.throwsError_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.throwsError
 
start() - Method in class org.apache.accumulo.core.client.mock.MockShell
 
start - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
start(I, GCMonitorService.getStatus_args, AsyncMethodCallback<GCStatus>) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
START - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
start(I, FateService.beginFateOperation_args, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.beginFateOperation
 
start(I, FateService.executeFateOperation_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
 
start(I, FateService.finishFateOperation_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
 
start(I, FateService.waitForFateOperation_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.waitForFateOperation
 
start(I, MasterClientService.getMasterStats_args, AsyncMethodCallback<MasterMonitorInfo>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
 
start(I, MasterClientService.initiateFlush_args, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
 
start(I, MasterClientService.removeNamespaceProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeNamespaceProperty
 
start(I, MasterClientService.removeSystemProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeSystemProperty
 
start(I, MasterClientService.removeTableProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeTableProperty
 
start(I, MasterClientService.reportSplitExtent_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportSplitExtent
 
start(I, MasterClientService.reportTabletStatus_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportTabletStatus
 
start(I, MasterClientService.setMasterGoalState_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setMasterGoalState
 
start(I, MasterClientService.setNamespaceProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setNamespaceProperty
 
start(I, MasterClientService.setSystemProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setSystemProperty
 
start(I, MasterClientService.setTableProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setTableProperty
 
start(I, MasterClientService.shutdown_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdown
 
start(I, MasterClientService.shutdownTabletServer_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdownTabletServer
 
start(I, MasterClientService.waitForFlush_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForFlush
 
start(I, TabletClientService.applyUpdates_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
 
start(I, TabletClientService.bulkImport_args, AsyncMethodCallback<List<TKeyExtent>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
 
start(I, TabletClientService.chop_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
 
start(I, TabletClientService.closeConditionalUpdate_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
 
start(I, TabletClientService.closeMultiScan_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
 
start(I, TabletClientService.closeScan_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
 
start(I, TabletClientService.closeUpdate_args, AsyncMethodCallback<UpdateErrors>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
 
start(I, TabletClientService.compact_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
 
start(I, TabletClientService.conditionalUpdate_args, AsyncMethodCallback<List<TCMResult>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
 
start(I, TabletClientService.continueMultiScan_args, AsyncMethodCallback<MultiScanResult>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
 
start(I, TabletClientService.continueScan_args, AsyncMethodCallback<ScanResult>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
 
start(I, TabletClientService.fastHalt_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
 
start(I, TabletClientService.flush_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
 
start(I, TabletClientService.flushTablet_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
 
start(I, TabletClientService.getActiveCompactions_args, AsyncMethodCallback<List<ActiveCompaction>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
 
start(I, TabletClientService.getActiveScans_args, AsyncMethodCallback<List<ActiveScan>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
 
start(I, TabletClientService.getHistoricalStats_args, AsyncMethodCallback<TabletStats>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
 
start(I, TabletClientService.getTabletServerStatus_args, AsyncMethodCallback<TabletServerStatus>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
 
start(I, TabletClientService.getTabletStats_args, AsyncMethodCallback<List<TabletStats>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
 
start(I, TabletClientService.halt_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
 
start(I, TabletClientService.invalidateConditionalUpdate_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
 
start(I, TabletClientService.loadTablet_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
 
start(I, TabletClientService.removeLogs_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
 
start(I, TabletClientService.splitTablet_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
 
start(I, TabletClientService.startConditionalUpdate_args, AsyncMethodCallback<TConditionalSession>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
 
start(I, TabletClientService.startMultiScan_args, AsyncMethodCallback<InitialMultiScan>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startMultiScan
 
start(I, TabletClientService.startScan_args, AsyncMethodCallback<InitialScan>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startScan
 
start(I, TabletClientService.startUpdate_args, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
 
start(I, TabletClientService.unloadTablet_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
 
start(I, TabletClientService.update_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
 
start(String[]) - Method in class org.apache.accumulo.core.util.Merge
 
start(String) - Method in class org.apache.accumulo.core.util.OpTimer
 
start() - Method in class org.apache.accumulo.core.util.shell.Shell
 
start(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
START_BOUND - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
START_INCL - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
START_INCLUSIVE - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
START_ROW_OPT - Static variable in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
startDebugLogging() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
startDefaultLocalityGroup() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
startDefaultLocalityGroup() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
startDefaultLocalityGroup() - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
started - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
startKeyInclusive - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
startNewLocalityGroup(String, Set<ByteSequence>) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
startNewLocalityGroup(String, Set<ByteSequence>) - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
startNewLocalityGroup(String, Set<ByteSequence>) - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
startRow - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
startRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
startRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
startRowOpt() - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
startTracing(String) - Method in class org.apache.accumulo.core.cli.ClientOpts
 
startUpdate(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
startUpdate(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
startUpdate(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
startUpdate(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
Stat - Class in org.apache.accumulo.core.util
 
Stat() - Constructor for class org.apache.accumulo.core.util.Stat
 
state - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
state - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
state - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
StatisticsDisplayFormatter - Class in org.apache.accumulo.core.util.format
Does not show contents from scan, only displays statistics.
StatisticsDisplayFormatter() - Constructor for class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
 
StatsIterator - Class in org.apache.accumulo.core.iterators.system
 
StatsIterator(SortedKeyValueIterator<Key, Value>, AtomicLong, AtomicLong) - Constructor for class org.apache.accumulo.core.iterators.system.StatsIterator
 
status - Variable in class org.apache.accumulo.core.data.thrift.TCMResult
 
status - Variable in class org.apache.accumulo.core.master.thrift.DeadServer
 
status - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
status - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
STDIN - Static variable in class org.apache.accumulo.core.util.shell.ShellOptionsJC.PasswordConverter
 
stop - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
stop(String) - Method in class org.apache.accumulo.core.util.OpTimer
 
stop(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
stopIfActive(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
stopKeyInclusive - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
stopTabletServers - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
stopTracing() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
StopWatch<K extends Enum<K>> - Class in org.apache.accumulo.core.util
 
StopWatch(Class<K>) - Constructor for class org.apache.accumulo.core.util.StopWatch
 
strictlyPositive(int) - Static method in class org.apache.accumulo.core.util.ArgumentChecker
 
STRING - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
String overhead
STRING_ARRAY_ENCODER - Static variable in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
STRING_ENCODER - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
stringify(ColumnVisibility.Node, byte[], StringBuilder) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
 
StringLexicoder - Class in org.apache.accumulo.core.client.lexicoder
This lexicoder encodes/decodes a given String to/from bytes without further processing.
StringLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.StringLexicoder
 
StringMax - Class in org.apache.accumulo.core.iterators.aggregation
Deprecated.
since 1.4, replaced by MaxCombiner with LongCombiner.Type.STRING
StringMax() - Constructor for class org.apache.accumulo.core.iterators.aggregation.StringMax
Deprecated.
 
StringMin - Class in org.apache.accumulo.core.iterators.aggregation
Deprecated.
since 1.4, replaced by MinCombiner with LongCombiner.Type.STRING
StringMin() - Constructor for class org.apache.accumulo.core.iterators.aggregation.StringMin
Deprecated.
 
StringSummation - Class in org.apache.accumulo.core.iterators.aggregation
Deprecated.
since 1.4, replaced by SummingCombiner with LongCombiner.Type.STRING
StringSummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.StringSummation
Deprecated.
 
stringTopKey(SortedKeyValueIterator<Key, Value>) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
StringUtil - Class in org.apache.accumulo.core.util
 
StringUtil() - Constructor for class org.apache.accumulo.core.util.StringUtil
 
subSequence(int, int) - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
subSequence(int, int) - Method in class org.apache.accumulo.core.data.ByteSequence
 
subSequence(int, int) - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
success(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient
 
success(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncIface
 
success() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
success() - Method in interface org.apache.accumulo.core.client.impl.thrift.ThriftTest.Iface
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
success - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
success - Variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
success - Variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
success - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
success - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
sumDev - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
SummingArrayCombiner - Class in org.apache.accumulo.core.iterators.user
A Combiner that interprets Values as arrays of Longs and returns an array of element-wise sums.
SummingArrayCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
SummingArrayCombiner.DOSArrayEncoder<V> - Class in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.DOSArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
SummingArrayCombiner.FixedLongArrayEncoder - Class in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.FixedLongArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.FixedLongArrayEncoder
 
SummingArrayCombiner.StringArrayEncoder - Class in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.StringArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
 
SummingArrayCombiner.Type - Enum in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.VarLongArrayEncoder - Class in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.VarLongArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.VarLongArrayEncoder
 
SummingCombiner - Class in org.apache.accumulo.core.iterators.user
A Combiner that interprets Values as Longs and returns their sum.
SummingCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.SummingCombiner
 
supportsLocalityGroups() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
supportsLocalityGroups() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
supportsLocalityGroups() - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
SUPPRESS_ROW_VALUE - Static variable in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
swap() - Method in class org.apache.accumulo.core.util.Pair
 
switchNow() - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
 
symbols - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
SynchronizedIterator<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable> - Class in org.apache.accumulo.core.iterators.system
Wraps a SortedKeyValueIterator so that all of its methods are synchronized.
SynchronizedIterator() - Constructor for class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
SynchronizedIterator(SortedKeyValueIterator<K, V>) - Constructor for class org.apache.accumulo.core.iterators.system.SynchronizedIterator
 
sysPerm - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
systemNamespace() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Returns the name of the system reserved namespace
systemNamespace() - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
 
SystemPermission - Enum in org.apache.accumulo.core.security
Accumulo system permissions.
SystemPermissionsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
SystemPermissionsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.SystemPermissionsCommand
 

T

table - Variable in class org.apache.accumulo.core.client.mock.MockScannerBase
 
table - Variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
TableCommand - Class in org.apache.accumulo.core.util.shell.commands
 
TableCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.TableCommand
 
TableDeletedException - Exception in org.apache.accumulo.core.client
This exception is thrown if a table is deleted after an operation starts.
TableDeletedException(String) - Constructor for exception org.apache.accumulo.core.client.TableDeletedException
 
TableExistsException - Exception in org.apache.accumulo.core.client
Thrown when the table specified already exists, and it was expected that it didn't
TableExistsException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.TableExistsException
 
TableExistsException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.TableExistsException
 
TableExistsException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.TableExistsException
 
tableId - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
tableId - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
tableId - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
tableId - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
tableId - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
tableId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
tableId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
tableId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
tableID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
tableIdMap() - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Get a mapping of table name to internal table id.
tableIdMap() - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
Get a mapping of table name to internal table id.
TableInfo - Class in org.apache.accumulo.core.master.thrift
 
TableInfo() - Constructor for class org.apache.accumulo.core.master.thrift.TableInfo
 
TableInfo(long, long, int, int, double, double, double, double, Compacting, Compacting, Compacting, double) - Constructor for class org.apache.accumulo.core.master.thrift.TableInfo
 
TableInfo(TableInfo) - Constructor for class org.apache.accumulo.core.master.thrift.TableInfo
Performs a deep copy on other.
TableInfo._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tableMap - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
tableMap - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
tableName - Variable in class org.apache.accumulo.core.cli.ClientOnDefaultTable
 
tableName - Variable in class org.apache.accumulo.core.cli.ClientOnRequiredTable
 
tableName - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
tableName - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
tableName - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
tableName - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
tableName - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
tableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
tableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
tableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
tableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
TableNotFoundException - Exception in org.apache.accumulo.core.client
Thrown when the table specified doesn't exist when it was expected to
TableNotFoundException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.TableNotFoundException
 
TableNotFoundException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.TableNotFoundException
 
TableNotFoundException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.TableNotFoundException
 
TableNotFoundException(String, NamespaceNotFoundException) - Constructor for exception org.apache.accumulo.core.client.TableNotFoundException
 
TableOfflineException - Exception in org.apache.accumulo.core.client
 
TableOfflineException(Instance, String) - Constructor for exception org.apache.accumulo.core.client.TableOfflineException
 
tableOfMetadataRow(Text) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
TableOperation - Enum in org.apache.accumulo.core.client.impl.thrift
 
TableOperation - Class in org.apache.accumulo.core.util.shell.commands
 
TableOperation() - Constructor for class org.apache.accumulo.core.util.shell.commands.TableOperation
 
TableOperationExceptionType - Enum in org.apache.accumulo.core.client.impl.thrift
 
TableOperations - Interface in org.apache.accumulo.core.client.admin
Provides a class for administering tables
tableOperations() - Method in class org.apache.accumulo.core.client.Connector
Retrieves a TableOperations object to perform table functions, such as create and delete.
tableOperations() - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
tableOperations() - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
TableOperationsHelper - Class in org.apache.accumulo.core.client.admin
Deprecated.
since 1.6.0; not intended for public api and you should not use it.
TableOperationsHelper() - Constructor for class org.apache.accumulo.core.client.admin.TableOperationsHelper
Deprecated.
 
TableOperationsHelper - Class in org.apache.accumulo.core.client.impl
 
TableOperationsHelper() - Constructor for class org.apache.accumulo.core.client.impl.TableOperationsHelper
 
TableOperationsImpl - Class in org.apache.accumulo.core.client.admin
Deprecated.
since 1.6.0; not intended for public api and you should not use it.
TableOperationsImpl(Instance, Credentials) - Constructor for class org.apache.accumulo.core.client.admin.TableOperationsImpl
Deprecated.
 
TableOperationsImpl(Instance, TCredentials) - Constructor for class org.apache.accumulo.core.client.admin.TableOperationsImpl
Deprecated.
 
TableOperationsImpl - Class in org.apache.accumulo.core.client.impl
 
TableOperationsImpl(Instance, Credentials) - Constructor for class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
tableOpt() - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
tableOpt(String) - Static method in class org.apache.accumulo.core.util.shell.commands.OptUtil
 
tableOption - Static variable in class org.apache.accumulo.core.util.shell.ShellOptions
 
TablePermission - Enum in org.apache.accumulo.core.security
Accumulo table permissions.
TablePermissionsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
TablePermissionsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.TablePermissionsCommand
 
tables - Variable in class org.apache.accumulo.core.client.admin.DiskUsage
 
Tables - Class in org.apache.accumulo.core.client.impl
 
Tables() - Constructor for class org.apache.accumulo.core.client.impl.Tables
 
tables - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
tables - Variable in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
TablesCommand - Class in org.apache.accumulo.core.util.shell.commands
 
TablesCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.TablesCommand
 
TableState - Enum in org.apache.accumulo.core.master.state.tables
 
tablet - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
tablet_extent - Variable in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
tablet_location - Variable in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
tablet_session - Variable in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
TabletClientService - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService
 
TabletClientService.applyUpdates_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.applyUpdates_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
TabletClientService.applyUpdates_args(TInfo, long, TKeyExtent, List<TMutation>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
TabletClientService.applyUpdates_args(TabletClientService.applyUpdates_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
Performs a deep copy on other.
TabletClientService.applyUpdates_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.AsyncClient - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
TabletClientService.AsyncClient.applyUpdates_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.applyUpdates_call(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.applyUpdates_call
 
TabletClientService.AsyncClient.bulkImport_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.bulkImport_call(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.bulkImport_call
 
TabletClientService.AsyncClient.chop_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.chop_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.chop_call
 
TabletClientService.AsyncClient.closeConditionalUpdate_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.closeConditionalUpdate_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeConditionalUpdate_call
 
TabletClientService.AsyncClient.closeMultiScan_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.closeMultiScan_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeMultiScan_call
 
TabletClientService.AsyncClient.closeScan_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.closeScan_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeScan_call
 
TabletClientService.AsyncClient.closeUpdate_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.closeUpdate_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeUpdate_call
 
TabletClientService.AsyncClient.compact_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.compact_call(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compact_call
 
TabletClientService.AsyncClient.conditionalUpdate_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.conditionalUpdate_call(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.conditionalUpdate_call
 
TabletClientService.AsyncClient.continueMultiScan_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.continueMultiScan_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueMultiScan_call
 
TabletClientService.AsyncClient.continueScan_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.continueScan_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueScan_call
 
TabletClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.Factory
 
TabletClientService.AsyncClient.fastHalt_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.fastHalt_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.fastHalt_call
 
TabletClientService.AsyncClient.flush_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.flush_call(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flush_call
 
TabletClientService.AsyncClient.flushTablet_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.flushTablet_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flushTablet_call
 
TabletClientService.AsyncClient.getActiveCompactions_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.getActiveCompactions_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveCompactions_call
 
TabletClientService.AsyncClient.getActiveScans_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.getActiveScans_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveScans_call
 
TabletClientService.AsyncClient.getHistoricalStats_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.getHistoricalStats_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getHistoricalStats_call
 
TabletClientService.AsyncClient.getTabletServerStatus_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.getTabletServerStatus_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletServerStatus_call
 
TabletClientService.AsyncClient.getTabletStats_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.getTabletStats_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletStats_call
 
TabletClientService.AsyncClient.halt_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.halt_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.halt_call
 
TabletClientService.AsyncClient.invalidateConditionalUpdate_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.invalidateConditionalUpdate_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.invalidateConditionalUpdate_call
 
TabletClientService.AsyncClient.loadTablet_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.loadTablet_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.loadTablet_call
 
TabletClientService.AsyncClient.removeLogs_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.removeLogs_call(TInfo, TCredentials, List<String>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.removeLogs_call
 
TabletClientService.AsyncClient.splitTablet_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.splitTablet_call(TInfo, TCredentials, TKeyExtent, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.splitTablet_call
 
TabletClientService.AsyncClient.startConditionalUpdate_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.startConditionalUpdate_call(TInfo, TCredentials, List<ByteBuffer>, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startConditionalUpdate_call
 
TabletClientService.AsyncClient.startMultiScan_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.startMultiScan_call(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startMultiScan_call
 
TabletClientService.AsyncClient.startScan_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.startScan_call(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startScan_call
 
TabletClientService.AsyncClient.startUpdate_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.startUpdate_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startUpdate_call
 
TabletClientService.AsyncClient.unloadTablet_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.unloadTablet_call(TInfo, TCredentials, String, TKeyExtent, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.unloadTablet_call
 
TabletClientService.AsyncClient.update_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncClient.update_call(TInfo, TCredentials, TKeyExtent, TMutation, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.update_call
 
TabletClientService.AsyncIface - Interface in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor
 
TabletClientService.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor
 
TabletClientService.AsyncProcessor.applyUpdates<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.applyUpdates() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
 
TabletClientService.AsyncProcessor.bulkImport<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.bulkImport() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
 
TabletClientService.AsyncProcessor.chop<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.chop() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
 
TabletClientService.AsyncProcessor.closeConditionalUpdate<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.closeConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
 
TabletClientService.AsyncProcessor.closeMultiScan<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.closeMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
 
TabletClientService.AsyncProcessor.closeScan<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.closeScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
 
TabletClientService.AsyncProcessor.closeUpdate<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.closeUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
 
TabletClientService.AsyncProcessor.compact<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.compact() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
 
TabletClientService.AsyncProcessor.conditionalUpdate<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.conditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
 
TabletClientService.AsyncProcessor.continueMultiScan<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.continueMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
 
TabletClientService.AsyncProcessor.continueScan<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.continueScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
 
TabletClientService.AsyncProcessor.fastHalt<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.fastHalt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
 
TabletClientService.AsyncProcessor.flush<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.flush() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
 
TabletClientService.AsyncProcessor.flushTablet<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.flushTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
 
TabletClientService.AsyncProcessor.getActiveCompactions<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.getActiveCompactions() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
 
TabletClientService.AsyncProcessor.getActiveScans<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.getActiveScans() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
 
TabletClientService.AsyncProcessor.getHistoricalStats<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.getHistoricalStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
 
TabletClientService.AsyncProcessor.getTabletServerStatus<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.getTabletServerStatus() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
 
TabletClientService.AsyncProcessor.getTabletStats<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.getTabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
 
TabletClientService.AsyncProcessor.halt<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.halt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
 
TabletClientService.AsyncProcessor.invalidateConditionalUpdate<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.invalidateConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
 
TabletClientService.AsyncProcessor.loadTablet<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.loadTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
 
TabletClientService.AsyncProcessor.removeLogs<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.removeLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
 
TabletClientService.AsyncProcessor.splitTablet<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.splitTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
 
TabletClientService.AsyncProcessor.startConditionalUpdate<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.startConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
 
TabletClientService.AsyncProcessor.startMultiScan<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.startMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startMultiScan
 
TabletClientService.AsyncProcessor.startScan<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.startScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startScan
 
TabletClientService.AsyncProcessor.startUpdate<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.startUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
 
TabletClientService.AsyncProcessor.unloadTablet<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.unloadTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
 
TabletClientService.AsyncProcessor.update<I extends TabletClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.AsyncProcessor.update() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
 
TabletClientService.bulkImport_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.bulkImport_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
TabletClientService.bulkImport_args(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
TabletClientService.bulkImport_args(TabletClientService.bulkImport_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Performs a deep copy on other.
TabletClientService.bulkImport_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.bulkImport_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.bulkImport_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
TabletClientService.bulkImport_result(List<TKeyExtent>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
TabletClientService.bulkImport_result(TabletClientService.bulkImport_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
Performs a deep copy on other.
TabletClientService.bulkImport_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.chop_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.chop_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
TabletClientService.chop_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
TabletClientService.chop_args(TabletClientService.chop_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
Performs a deep copy on other.
TabletClientService.chop_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.Client - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Client(TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
TabletClientService.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
TabletClientService.Client.Factory - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Client.Factory() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
 
TabletClientService.closeConditionalUpdate_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.closeConditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
TabletClientService.closeConditionalUpdate_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
TabletClientService.closeConditionalUpdate_args(TabletClientService.closeConditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
Performs a deep copy on other.
TabletClientService.closeConditionalUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.closeMultiScan_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.closeMultiScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
TabletClientService.closeMultiScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
TabletClientService.closeMultiScan_args(TabletClientService.closeMultiScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
Performs a deep copy on other.
TabletClientService.closeMultiScan_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.closeMultiScan_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.closeMultiScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
TabletClientService.closeMultiScan_result(NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
TabletClientService.closeMultiScan_result(TabletClientService.closeMultiScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
Performs a deep copy on other.
TabletClientService.closeMultiScan_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.closeScan_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.closeScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
TabletClientService.closeScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
TabletClientService.closeScan_args(TabletClientService.closeScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
Performs a deep copy on other.
TabletClientService.closeScan_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.closeUpdate_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.closeUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
TabletClientService.closeUpdate_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
TabletClientService.closeUpdate_args(TabletClientService.closeUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
Performs a deep copy on other.
TabletClientService.closeUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.closeUpdate_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.closeUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
TabletClientService.closeUpdate_result(UpdateErrors, NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
TabletClientService.closeUpdate_result(TabletClientService.closeUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
Performs a deep copy on other.
TabletClientService.closeUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.compact_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.compact_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
TabletClientService.compact_args(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
TabletClientService.compact_args(TabletClientService.compact_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Performs a deep copy on other.
TabletClientService.compact_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.conditionalUpdate_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.conditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
TabletClientService.conditionalUpdate_args(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
TabletClientService.conditionalUpdate_args(TabletClientService.conditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
Performs a deep copy on other.
TabletClientService.conditionalUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.conditionalUpdate_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.conditionalUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
TabletClientService.conditionalUpdate_result(List<TCMResult>, NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
TabletClientService.conditionalUpdate_result(TabletClientService.conditionalUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
Performs a deep copy on other.
TabletClientService.conditionalUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.continueMultiScan_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.continueMultiScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
TabletClientService.continueMultiScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
TabletClientService.continueMultiScan_args(TabletClientService.continueMultiScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
Performs a deep copy on other.
TabletClientService.continueMultiScan_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.continueMultiScan_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.continueMultiScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
TabletClientService.continueMultiScan_result(MultiScanResult, NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
TabletClientService.continueMultiScan_result(TabletClientService.continueMultiScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
Performs a deep copy on other.
TabletClientService.continueMultiScan_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.continueScan_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.continueScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
TabletClientService.continueScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
TabletClientService.continueScan_args(TabletClientService.continueScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
Performs a deep copy on other.
TabletClientService.continueScan_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.continueScan_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.continueScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
TabletClientService.continueScan_result(ScanResult, NoSuchScanIDException, NotServingTabletException, TooManyFilesException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
TabletClientService.continueScan_result(TabletClientService.continueScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
Performs a deep copy on other.
TabletClientService.continueScan_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.fastHalt_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.fastHalt_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
TabletClientService.fastHalt_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
TabletClientService.fastHalt_args(TabletClientService.fastHalt_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
Performs a deep copy on other.
TabletClientService.fastHalt_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.flush_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.flush_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
TabletClientService.flush_args(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
TabletClientService.flush_args(TabletClientService.flush_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Performs a deep copy on other.
TabletClientService.flush_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.flushTablet_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.flushTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
TabletClientService.flushTablet_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
TabletClientService.flushTablet_args(TabletClientService.flushTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
Performs a deep copy on other.
TabletClientService.flushTablet_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getActiveCompactions_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getActiveCompactions_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
TabletClientService.getActiveCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
TabletClientService.getActiveCompactions_args(TabletClientService.getActiveCompactions_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
Performs a deep copy on other.
TabletClientService.getActiveCompactions_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getActiveCompactions_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getActiveCompactions_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
TabletClientService.getActiveCompactions_result(List<ActiveCompaction>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
TabletClientService.getActiveCompactions_result(TabletClientService.getActiveCompactions_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
Performs a deep copy on other.
TabletClientService.getActiveCompactions_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getActiveScans_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getActiveScans_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
TabletClientService.getActiveScans_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
TabletClientService.getActiveScans_args(TabletClientService.getActiveScans_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
Performs a deep copy on other.
TabletClientService.getActiveScans_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getActiveScans_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getActiveScans_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
TabletClientService.getActiveScans_result(List<ActiveScan>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
TabletClientService.getActiveScans_result(TabletClientService.getActiveScans_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
Performs a deep copy on other.
TabletClientService.getActiveScans_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getHistoricalStats_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getHistoricalStats_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
TabletClientService.getHistoricalStats_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
TabletClientService.getHistoricalStats_args(TabletClientService.getHistoricalStats_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
Performs a deep copy on other.
TabletClientService.getHistoricalStats_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getHistoricalStats_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getHistoricalStats_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
TabletClientService.getHistoricalStats_result(TabletStats, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
TabletClientService.getHistoricalStats_result(TabletClientService.getHistoricalStats_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
Performs a deep copy on other.
TabletClientService.getHistoricalStats_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getTabletServerStatus_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getTabletServerStatus_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
TabletClientService.getTabletServerStatus_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
TabletClientService.getTabletServerStatus_args(TabletClientService.getTabletServerStatus_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
Performs a deep copy on other.
TabletClientService.getTabletServerStatus_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getTabletServerStatus_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getTabletServerStatus_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
TabletClientService.getTabletServerStatus_result(TabletServerStatus, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
TabletClientService.getTabletServerStatus_result(TabletClientService.getTabletServerStatus_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
Performs a deep copy on other.
TabletClientService.getTabletServerStatus_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getTabletStats_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getTabletStats_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
TabletClientService.getTabletStats_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
TabletClientService.getTabletStats_args(TabletClientService.getTabletStats_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
Performs a deep copy on other.
TabletClientService.getTabletStats_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.getTabletStats_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.getTabletStats_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
TabletClientService.getTabletStats_result(List<TabletStats>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
TabletClientService.getTabletStats_result(TabletClientService.getTabletStats_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
Performs a deep copy on other.
TabletClientService.getTabletStats_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.halt_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.halt_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
TabletClientService.halt_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
TabletClientService.halt_args(TabletClientService.halt_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
Performs a deep copy on other.
TabletClientService.halt_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.halt_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.halt_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
TabletClientService.halt_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
TabletClientService.halt_result(TabletClientService.halt_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
Performs a deep copy on other.
TabletClientService.halt_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.Iface - Interface in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.invalidateConditionalUpdate_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.invalidateConditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
TabletClientService.invalidateConditionalUpdate_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
TabletClientService.invalidateConditionalUpdate_args(TabletClientService.invalidateConditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
Performs a deep copy on other.
TabletClientService.invalidateConditionalUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.invalidateConditionalUpdate_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.invalidateConditionalUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
TabletClientService.invalidateConditionalUpdate_result(TabletClientService.invalidateConditionalUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
Performs a deep copy on other.
TabletClientService.invalidateConditionalUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.loadTablet_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.loadTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
TabletClientService.loadTablet_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
TabletClientService.loadTablet_args(TabletClientService.loadTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
Performs a deep copy on other.
TabletClientService.loadTablet_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.Processor<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor(I) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor
 
TabletClientService.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor
 
TabletClientService.Processor.applyUpdates<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.applyUpdates() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
 
TabletClientService.Processor.bulkImport<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.bulkImport() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
 
TabletClientService.Processor.chop<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.chop() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
 
TabletClientService.Processor.closeConditionalUpdate<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.closeConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
 
TabletClientService.Processor.closeMultiScan<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.closeMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeMultiScan
 
TabletClientService.Processor.closeScan<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.closeScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeScan
 
TabletClientService.Processor.closeUpdate<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.closeUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
 
TabletClientService.Processor.compact<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.compact() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
 
TabletClientService.Processor.conditionalUpdate<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.conditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
 
TabletClientService.Processor.continueMultiScan<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.continueMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueMultiScan
 
TabletClientService.Processor.continueScan<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.continueScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueScan
 
TabletClientService.Processor.fastHalt<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.fastHalt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
 
TabletClientService.Processor.flush<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.flush() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
 
TabletClientService.Processor.flushTablet<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.flushTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
 
TabletClientService.Processor.getActiveCompactions<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.getActiveCompactions() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
 
TabletClientService.Processor.getActiveScans<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.getActiveScans() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveScans
 
TabletClientService.Processor.getHistoricalStats<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.getHistoricalStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
 
TabletClientService.Processor.getTabletServerStatus<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.getTabletServerStatus() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
 
TabletClientService.Processor.getTabletStats<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.getTabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
 
TabletClientService.Processor.halt<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.halt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
 
TabletClientService.Processor.invalidateConditionalUpdate<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.invalidateConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
 
TabletClientService.Processor.loadTablet<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.loadTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
 
TabletClientService.Processor.removeLogs<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.removeLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
 
TabletClientService.Processor.splitTablet<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.splitTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
 
TabletClientService.Processor.startConditionalUpdate<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.startConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
 
TabletClientService.Processor.startMultiScan<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.startMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startMultiScan
 
TabletClientService.Processor.startScan<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.startScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startScan
 
TabletClientService.Processor.startUpdate<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.startUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
 
TabletClientService.Processor.unloadTablet<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.unloadTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
 
TabletClientService.Processor.update<I extends TabletClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor.update() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
 
TabletClientService.removeLogs_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.removeLogs_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
TabletClientService.removeLogs_args(TInfo, TCredentials, List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
TabletClientService.removeLogs_args(TabletClientService.removeLogs_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
Performs a deep copy on other.
TabletClientService.removeLogs_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.splitTablet_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.splitTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
TabletClientService.splitTablet_args(TInfo, TCredentials, TKeyExtent, ByteBuffer) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
TabletClientService.splitTablet_args(TabletClientService.splitTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
Performs a deep copy on other.
TabletClientService.splitTablet_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.splitTablet_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.splitTablet_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
TabletClientService.splitTablet_result(ThriftSecurityException, NotServingTabletException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
TabletClientService.splitTablet_result(TabletClientService.splitTablet_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
Performs a deep copy on other.
TabletClientService.splitTablet_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.startConditionalUpdate_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.startConditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
TabletClientService.startConditionalUpdate_args(TInfo, TCredentials, List<ByteBuffer>, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
TabletClientService.startConditionalUpdate_args(TabletClientService.startConditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
Performs a deep copy on other.
TabletClientService.startConditionalUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.startConditionalUpdate_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.startConditionalUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
TabletClientService.startConditionalUpdate_result(TConditionalSession, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
TabletClientService.startConditionalUpdate_result(TabletClientService.startConditionalUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
Performs a deep copy on other.
TabletClientService.startConditionalUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.startMultiScan_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.startMultiScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
TabletClientService.startMultiScan_args(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
TabletClientService.startMultiScan_args(TabletClientService.startMultiScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Performs a deep copy on other.
TabletClientService.startMultiScan_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.startMultiScan_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.startMultiScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
TabletClientService.startMultiScan_result(InitialMultiScan, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
TabletClientService.startMultiScan_result(TabletClientService.startMultiScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
Performs a deep copy on other.
TabletClientService.startMultiScan_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.startScan_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.startScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
TabletClientService.startScan_args(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
TabletClientService.startScan_args(TabletClientService.startScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Performs a deep copy on other.
TabletClientService.startScan_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.startScan_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.startScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
TabletClientService.startScan_result(InitialScan, ThriftSecurityException, NotServingTabletException, TooManyFilesException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
TabletClientService.startScan_result(TabletClientService.startScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
Performs a deep copy on other.
TabletClientService.startScan_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.startUpdate_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.startUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
TabletClientService.startUpdate_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
TabletClientService.startUpdate_args(TabletClientService.startUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
Performs a deep copy on other.
TabletClientService.startUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.startUpdate_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.startUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
TabletClientService.startUpdate_result(long, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
TabletClientService.startUpdate_result(TabletClientService.startUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
Performs a deep copy on other.
TabletClientService.startUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.unloadTablet_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.unloadTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
TabletClientService.unloadTablet_args(TInfo, TCredentials, String, TKeyExtent, boolean) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
TabletClientService.unloadTablet_args(TabletClientService.unloadTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
Performs a deep copy on other.
TabletClientService.unloadTablet_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.update_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.update_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
TabletClientService.update_args(TInfo, TCredentials, TKeyExtent, TMutation) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
TabletClientService.update_args(TabletClientService.update_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
Performs a deep copy on other.
TabletClientService.update_args._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletClientService.update_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.update_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
TabletClientService.update_result(ThriftSecurityException, NotServingTabletException, ConstraintViolationException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
TabletClientService.update_result(TabletClientService.update_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
Performs a deep copy on other.
TabletClientService.update_result._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tabletId - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
TabletLoadState - Enum in org.apache.accumulo.core.master.thrift
 
TabletLocator - Class in org.apache.accumulo.core.client.impl
 
TabletLocator() - Constructor for class org.apache.accumulo.core.client.impl.TabletLocator
 
TabletLocator.TabletLocation - Class in org.apache.accumulo.core.client.impl
 
TabletLocator.TabletLocation(KeyExtent, String, String) - Constructor for class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
TabletLocator.TabletLocations - Class in org.apache.accumulo.core.client.impl
 
TabletLocator.TabletLocations(List<TabletLocator.TabletLocation>, List<KeyExtent>) - Constructor for class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocations
 
TabletLocator.TabletServerMutations<T extends Mutation> - Class in org.apache.accumulo.core.client.impl
 
TabletLocator.TabletServerMutations(String) - Constructor for class org.apache.accumulo.core.client.impl.TabletLocator.TabletServerMutations
 
TabletLocatorImpl - Class in org.apache.accumulo.core.client.impl
 
TabletLocatorImpl(Text, TabletLocator, TabletLocatorImpl.TabletLocationObtainer, TabletLocatorImpl.TabletServerLockChecker) - Constructor for class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
TabletLocatorImpl.TabletLocationObtainer - Interface in org.apache.accumulo.core.client.impl
 
TabletLocatorImpl.TabletServerLockChecker - Interface in org.apache.accumulo.core.client.impl
 
tablets - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
tabletServer - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
TabletServerBatchDeleter - Class in org.apache.accumulo.core.client.impl
 
TabletServerBatchDeleter(Instance, Credentials, String, Authorizations, int, BatchWriterConfig) - Constructor for class org.apache.accumulo.core.client.impl.TabletServerBatchDeleter
 
TabletServerBatchReader - Class in org.apache.accumulo.core.client.impl
 
TabletServerBatchReader(Instance, Credentials, String, Authorizations, int) - Constructor for class org.apache.accumulo.core.client.impl.TabletServerBatchReader
 
TabletServerBatchReaderIterator - Class in org.apache.accumulo.core.client.impl
 
TabletServerBatchReaderIterator(Instance, Credentials, String, Authorizations, ArrayList<Range>, int, ExecutorService, ScannerOptions, long) - Constructor for class org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator
 
TabletServerBatchReaderIterator.ResultReceiver - Interface in org.apache.accumulo.core.client.impl
 
TabletServerBatchWriter - Class in org.apache.accumulo.core.client.impl
 
TabletServerBatchWriter(Instance, Credentials, BatchWriterConfig) - Constructor for class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
 
TabletServerStatus - Class in org.apache.accumulo.core.master.thrift
 
TabletServerStatus() - Constructor for class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
TabletServerStatus(Map<String, TableInfo>, long, String, double, long, long, long, long, long, long, List<RecoveryStatus>) - Constructor for class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
TabletServerStatus(TabletServerStatus) - Constructor for class org.apache.accumulo.core.master.thrift.TabletServerStatus
Performs a deep copy on other.
TabletServerStatus._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletSplit - Class in org.apache.accumulo.core.master.thrift
 
TabletSplit() - Constructor for class org.apache.accumulo.core.master.thrift.TabletSplit
 
TabletSplit(TKeyExtent, List<TKeyExtent>) - Constructor for class org.apache.accumulo.core.master.thrift.TabletSplit
 
TabletSplit(TabletSplit) - Constructor for class org.apache.accumulo.core.master.thrift.TabletSplit
Performs a deep copy on other.
TabletSplit._Fields - Enum in org.apache.accumulo.core.master.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletStats - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
TabletStats(TKeyExtent, ActionStats, ActionStats, ActionStats, long, double, double, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
TabletStats(TabletStats) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Performs a deep copy on other.
TabletStats._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletType - Enum in org.apache.accumulo.core.client.impl
 
tblNspcPerm - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
tblPerm - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
TBufferedSocket - Class in org.apache.accumulo.core.util
 
TBufferedSocket(TSocket, int) - Constructor for class org.apache.accumulo.core.util.TBufferedSocket
 
TCMResult - Class in org.apache.accumulo.core.data.thrift
 
TCMResult() - Constructor for class org.apache.accumulo.core.data.thrift.TCMResult
 
TCMResult(long, TCMStatus) - Constructor for class org.apache.accumulo.core.data.thrift.TCMResult
 
TCMResult(TCMResult) - Constructor for class org.apache.accumulo.core.data.thrift.TCMResult
Performs a deep copy on other.
TCMResult._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCMStatus - Enum in org.apache.accumulo.core.data.thrift
 
TColumn - Class in org.apache.accumulo.core.data.thrift
 
TColumn() - Constructor for class org.apache.accumulo.core.data.thrift.TColumn
 
TColumn(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.data.thrift.TColumn
 
TColumn(TColumn) - Constructor for class org.apache.accumulo.core.data.thrift.TColumn
Performs a deep copy on other.
TColumn._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCondition - Class in org.apache.accumulo.core.data.thrift
 
TCondition() - Constructor for class org.apache.accumulo.core.data.thrift.TCondition
 
TCondition(ByteBuffer, ByteBuffer, ByteBuffer, long, boolean, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.data.thrift.TCondition
 
TCondition(TCondition) - Constructor for class org.apache.accumulo.core.data.thrift.TCondition
Performs a deep copy on other.
TCondition._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TConditionalMutation - Class in org.apache.accumulo.core.data.thrift
 
TConditionalMutation() - Constructor for class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
TConditionalMutation(List<TCondition>, TMutation, long) - Constructor for class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
TConditionalMutation(TConditionalMutation) - Constructor for class org.apache.accumulo.core.data.thrift.TConditionalMutation
Performs a deep copy on other.
TConditionalMutation._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TConditionalSession - Class in org.apache.accumulo.core.data.thrift
 
TConditionalSession() - Constructor for class org.apache.accumulo.core.data.thrift.TConditionalSession
 
TConditionalSession(long, String, long) - Constructor for class org.apache.accumulo.core.data.thrift.TConditionalSession
 
TConditionalSession(TConditionalSession) - Constructor for class org.apache.accumulo.core.data.thrift.TConditionalSession
Performs a deep copy on other.
TConditionalSession._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TConstraintViolationSummary - Class in org.apache.accumulo.core.data.thrift
 
TConstraintViolationSummary() - Constructor for class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
TConstraintViolationSummary(String, short, String, long) - Constructor for class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
TConstraintViolationSummary(TConstraintViolationSummary) - Constructor for class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
Performs a deep copy on other.
TConstraintViolationSummary._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCredentials - Class in org.apache.accumulo.core.security.thrift
 
TCredentials() - Constructor for class org.apache.accumulo.core.security.thrift.TCredentials
 
TCredentials(String, String, ByteBuffer, String) - Constructor for class org.apache.accumulo.core.security.thrift.TCredentials
 
TCredentials(TCredentials) - Constructor for class org.apache.accumulo.core.security.thrift.TCredentials
Performs a deep copy on other.
TCredentials._Fields - Enum in org.apache.accumulo.core.security.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCVST - Static variable in class org.apache.accumulo.core.client.impl.Translators
 
TDiskUsage - Class in org.apache.accumulo.core.client.impl.thrift
 
TDiskUsage() - Constructor for class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
TDiskUsage(List<String>, long) - Constructor for class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
TDiskUsage(TDiskUsage) - Constructor for class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
Performs a deep copy on other.
TDiskUsage._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
term - Variable in class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
term - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
testClassLoad(String, String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Test to see if the instance can load the given class as the given type.
testClassLoad(String, String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Test to see if the instance can load the given class as the given type.
testClassLoad(String, String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Test to see if the instance can load the given class as the given type.
testClassLoad(String, String) - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
 
testClassLoad(String, String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
 
testClassLoad(String, String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
 
testEncoder(V) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Tests whether v remains the same when encoded and decoded with the current encoder.
testEncoder(TypedValueCombiner.Encoder<V>, V) - Static method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Tests whether v remains the same when encoded and decoded with the given encoder.
TextLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder that preserves a Text's native sort order.
TextLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.TextLexicoder
 
TextUtil - Class in org.apache.accumulo.core.util
 
TextUtil() - Constructor for class org.apache.accumulo.core.util.TextUtil
 
ThriftScanner - Class in org.apache.accumulo.core.client.impl
 
ThriftScanner() - Constructor for class org.apache.accumulo.core.client.impl.ThriftScanner
 
ThriftScanner.ScanState - Class in org.apache.accumulo.core.client.impl
 
ThriftScanner.ScanState(Instance, Credentials, Text, Authorizations, Range, SortedSet<Column>, int, List<IterInfo>, Map<String, Map<String, String>>, boolean) - Constructor for class org.apache.accumulo.core.client.impl.ThriftScanner.ScanState
 
ThriftScanner.ScanState(Instance, Credentials, Text, Authorizations, Range, SortedSet<Column>, int, List<IterInfo>, Map<String, Map<String, String>>, boolean, long) - Constructor for class org.apache.accumulo.core.client.impl.ThriftScanner.ScanState
 
ThriftScanner.ScanTimedOutException - Exception in org.apache.accumulo.core.client.impl
 
ThriftScanner.ScanTimedOutException() - Constructor for exception org.apache.accumulo.core.client.impl.ThriftScanner.ScanTimedOutException
 
ThriftSecurityException - Exception in org.apache.accumulo.core.client.impl.thrift
 
ThriftSecurityException() - Constructor for exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
ThriftSecurityException(String, SecurityErrorCode) - Constructor for exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
ThriftSecurityException(ThriftSecurityException) - Constructor for exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
Performs a deep copy on other.
ThriftSecurityException._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTableOperationException - Exception in org.apache.accumulo.core.client.impl.thrift
 
ThriftTableOperationException() - Constructor for exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
ThriftTableOperationException(String, String, TableOperation, TableOperationExceptionType, String) - Constructor for exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
ThriftTableOperationException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
Performs a deep copy on other.
ThriftTableOperationException._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest
 
ThriftTest.AsyncClient - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient
 
ThriftTest.AsyncClient.Factory - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.Factory
 
ThriftTest.AsyncClient.fails_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncClient.fails_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.fails_call
 
ThriftTest.AsyncClient.success_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncClient.success_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.success_call
 
ThriftTest.AsyncClient.throwsError_call - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncClient.throwsError_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.throwsError_call
 
ThriftTest.AsyncIface - Interface in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncProcessor<I extends ThriftTest.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor
 
ThriftTest.AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor
 
ThriftTest.AsyncProcessor.fails<I extends ThriftTest.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncProcessor.fails() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
 
ThriftTest.AsyncProcessor.success<I extends ThriftTest.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncProcessor.success() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.success
 
ThriftTest.AsyncProcessor.throwsError<I extends ThriftTest.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.AsyncProcessor.throwsError() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.throwsError
 
ThriftTest.Client - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.Client(TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
ThriftTest.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
ThriftTest.Client.Factory - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.Client.Factory() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client.Factory
 
ThriftTest.fails_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.fails_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
ThriftTest.fails_args(ThriftTest.fails_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
Performs a deep copy on other.
ThriftTest.fails_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.fails_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.fails_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
ThriftTest.fails_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
ThriftTest.fails_result(ThriftTest.fails_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
Performs a deep copy on other.
ThriftTest.fails_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.Iface - Interface in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.Processor<I extends ThriftTest.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.Processor(I) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor
 
ThriftTest.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor
 
ThriftTest.Processor.fails<I extends ThriftTest.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.Processor.fails() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.fails
 
ThriftTest.Processor.success<I extends ThriftTest.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.Processor.success() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.success
 
ThriftTest.Processor.throwsError<I extends ThriftTest.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.Processor.throwsError() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.throwsError
 
ThriftTest.success_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.success_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
ThriftTest.success_args(ThriftTest.success_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
Performs a deep copy on other.
ThriftTest.success_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.success_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.success_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
ThriftTest.success_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
ThriftTest.success_result(ThriftTest.success_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
Performs a deep copy on other.
ThriftTest.success_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.throwsError_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.throwsError_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
ThriftTest.throwsError_args(ThriftTest.throwsError_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
Performs a deep copy on other.
ThriftTest.throwsError_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.throwsError_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ThriftTest.throwsError_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
ThriftTest.throwsError_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
ThriftTest.throwsError_result(ThriftTest.throwsError_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
Performs a deep copy on other.
ThriftTest.throwsError_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTransportKey - Class in org.apache.accumulo.core.client.impl
 
ThriftTransportKey(String, long, SslConnectionParams) - Constructor for class org.apache.accumulo.core.client.impl.ThriftTransportKey
 
ThriftTransportPool - Class in org.apache.accumulo.core.client.impl
 
ThriftTransportPool.TransportPoolShutdownException - Exception in org.apache.accumulo.core.client.impl
 
ThriftTransportPool.TransportPoolShutdownException() - Constructor for exception org.apache.accumulo.core.client.impl.ThriftTransportPool.TransportPoolShutdownException
 
ThriftUtil - Class in org.apache.accumulo.core.util
 
ThriftUtil() - Constructor for class org.apache.accumulo.core.util.ThriftUtil
 
ThriftUtil.TraceProtocol - Class in org.apache.accumulo.core.util
 
ThriftUtil.TraceProtocol(TTransport) - Constructor for class org.apache.accumulo.core.util.ThriftUtil.TraceProtocol
 
ThriftUtil.TraceProtocolFactory - Class in org.apache.accumulo.core.util
 
ThriftUtil.TraceProtocolFactory() - Constructor for class org.apache.accumulo.core.util.ThriftUtil.TraceProtocolFactory
 
throwsError(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient
 
throwsError(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncIface
 
throwsError() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
 
throwsError() - Method in interface org.apache.accumulo.core.client.impl.thrift.ThriftTest.Iface
 
tid - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
tid - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
tid - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
TIME_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds the TimeType
TimedOutException - Exception in org.apache.accumulo.core.client
 
TimedOutException(Set<String>) - Constructor for exception org.apache.accumulo.core.client.TimedOutException
 
TimedOutException(String) - Constructor for exception org.apache.accumulo.core.client.TimedOutException
 
timeOut - Variable in class org.apache.accumulo.core.client.impl.ScannerOptions
 
TimeoutTabletLocator - Class in org.apache.accumulo.core.client.impl
 
TimeoutTabletLocator(TabletLocator, long) - Constructor for class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
 
TimeSettingIterator - Class in org.apache.accumulo.core.iterators.system
 
TimeSettingIterator(SortedKeyValueIterator<Key, Value>, long) - Constructor for class org.apache.accumulo.core.iterators.system.TimeSettingIterator
 
timestamp - Variable in class org.apache.accumulo.core.data.Key
 
timestamp - Variable in class org.apache.accumulo.core.data.thrift.TKey
 
timestamp - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
TimestampFilter - Class in org.apache.accumulo.core.iterators.user
A Filter that matches entries whose timestamps fall within a range.
TimestampFilter() - Constructor for class org.apache.accumulo.core.iterators.user.TimestampFilter
 
timestampOpt - Variable in class org.apache.accumulo.core.util.shell.commands.ScanCommand
 
TimeType - Enum in org.apache.accumulo.core.client.admin
The type of ordering to use for the table's entries (default is MILLIS)
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
TIteratorSetting - Class in org.apache.accumulo.core.tabletserver.thrift
 
TIteratorSetting() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
TIteratorSetting(int, String, String, Map<String, String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
TIteratorSetting(TIteratorSetting) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
Performs a deep copy on other.
TIteratorSetting._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TKET - Static variable in class org.apache.accumulo.core.client.impl.Translators
 
TKey - Class in org.apache.accumulo.core.data.thrift
 
TKey() - Constructor for class org.apache.accumulo.core.data.thrift.TKey
 
TKey(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.accumulo.core.data.thrift.TKey
 
TKey(TKey) - Constructor for class org.apache.accumulo.core.data.thrift.TKey
Performs a deep copy on other.
TKey._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TKeyExtent - Class in org.apache.accumulo.core.data.thrift
 
TKeyExtent() - Constructor for class org.apache.accumulo.core.data.thrift.TKeyExtent
 
TKeyExtent(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.data.thrift.TKeyExtent
 
TKeyExtent(TKeyExtent) - Constructor for class org.apache.accumulo.core.data.thrift.TKeyExtent
Performs a deep copy on other.
TKeyExtent._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TKeyValue - Class in org.apache.accumulo.core.data.thrift
 
TKeyValue() - Constructor for class org.apache.accumulo.core.data.thrift.TKeyValue
 
TKeyValue(TKey, ByteBuffer) - Constructor for class org.apache.accumulo.core.data.thrift.TKeyValue
 
TKeyValue(TKeyValue) - Constructor for class org.apache.accumulo.core.data.thrift.TKeyValue
Performs a deep copy on other.
TKeyValue._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tmfe - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
tmfe - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
tmpVis - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
TMutation - Class in org.apache.accumulo.core.data.thrift
 
TMutation() - Constructor for class org.apache.accumulo.core.data.thrift.TMutation
 
TMutation(ByteBuffer, ByteBuffer, List<ByteBuffer>, int) - Constructor for class org.apache.accumulo.core.data.thrift.TMutation
 
TMutation(TMutation) - Constructor for class org.apache.accumulo.core.data.thrift.TMutation
Performs a deep copy on other.
TMutation._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
toArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
toArray() - Method in class org.apache.accumulo.core.data.ByteSequence
 
toArray(List<byte[]>) - Static method in class org.apache.accumulo.core.data.Value
 
toArray() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 
toAuth - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
toByteBuffer() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 
toByteBuffers(Collection<byte[]>) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toByteBuffers(ByteSequence) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toBytes() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
toBytes(ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toBytesList(Collection<ByteBuffer>) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toColumn() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
toDataRange() - Method in class org.apache.accumulo.core.data.KeyExtent
 
toe - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
toIteratorConfig(List<IteratorSetting>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
toIteratorSetting(TIteratorSetting) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
toIteratorSettings(IteratorConfig) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
token - Variable in class org.apache.accumulo.core.security.thrift.TCredentials
 
Token - Class in org.apache.accumulo.core.util.shell
 
Token() - Constructor for class org.apache.accumulo.core.util.shell.Token
 
Token(String) - Constructor for class org.apache.accumulo.core.util.shell.Token
 
Token(Collection<String>) - Constructor for class org.apache.accumulo.core.util.shell.Token
 
Token(Set<String>, Set<Token>) - Constructor for class org.apache.accumulo.core.util.shell.Token
 
tokenClassName - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
tokenClassName - Variable in class org.apache.accumulo.core.security.thrift.TCredentials
 
tokenFile - Variable in class org.apache.accumulo.core.cli.ClientOnRequiredTable
 
toList() - Method in class org.apache.accumulo.core.util.ByteArraySet
 
toMapEntry() - Method in class org.apache.accumulo.core.util.Pair
 
toMetadataRange() - Method in class org.apache.accumulo.core.data.KeyExtent
 
TooManyFilesException - Exception in org.apache.accumulo.core.tabletserver.thrift
 
TooManyFilesException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
TooManyFilesException(TKeyExtent) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
TooManyFilesException(TooManyFilesException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
Performs a deep copy on other.
TooManyFilesException._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
topKey - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
toPrintableString(byte[], int, int, int) - Static method in class org.apache.accumulo.core.data.Key
 
toString() - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
toString() - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
toString() - Method in class org.apache.accumulo.core.cli.ClientOpts.Password
 
toString() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
toString() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
toString() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
toString() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
toString() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
 
toString() - Method in class org.apache.accumulo.core.client.IteratorSetting
 
toString() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
toString() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
toString() - Method in enum org.apache.accumulo.core.conf.Property
 
toString() - Method in enum org.apache.accumulo.core.conf.PropertyType
 
toString() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
toString() - Method in class org.apache.accumulo.core.data.Column
 
toString() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
toString() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
toString() - Method in class org.apache.accumulo.core.data.Key
 
toString() - Method in class org.apache.accumulo.core.data.KeyExtent
 
toString() - Method in class org.apache.accumulo.core.data.Range
 
toString() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
toString() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
toString() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
toString() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
toString() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
toString() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
toString() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
toString() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
toString() - Method in class org.apache.accumulo.core.data.Value
 
toString() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Return a string representation of the version.
toString() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
toString() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
toString() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
toString() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
toString() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
toString() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
toString() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
toString() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
toString() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
toString() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
toString() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
toString() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
toString() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
toString() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
toString() - Method in class org.apache.accumulo.core.security.Authorizations
 
toString() - Method in class org.apache.accumulo.core.security.ColumnVisibility
 
toString() - Method in class org.apache.accumulo.core.security.Credentials
 
toString() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
toString() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
toString() - Method in class org.apache.accumulo.core.util.BinaryTree
 
toString() - Method in class org.apache.accumulo.core.util.BulkImportHelper.AssignmentStats
 
toString() - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
toString(ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toString() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
toString() - Method in class org.apache.accumulo.core.util.Pair
 
toString(String, String, String) - Method in class org.apache.accumulo.core.util.Pair
 
toString() - Method in class org.apache.accumulo.core.util.ServerServices
 
toString() - Method in enum org.apache.accumulo.core.util.shell.ShellCommandException.ErrorCode
 
toString() - Method in class org.apache.accumulo.core.util.shell.Token
 
toString() - Method in class org.apache.accumulo.core.util.Stat
 
toString() - Method in class org.apache.accumulo.core.util.Version
 
toString() - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
 
toString() - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
toStringNoTime() - Method in class org.apache.accumulo.core.data.Key
 
toText(ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toThrift() - Method in class org.apache.accumulo.core.data.Column
 
toThrift() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
toThrift() - Method in class org.apache.accumulo.core.data.Key
 
toThrift() - Method in class org.apache.accumulo.core.data.KeyExtent
 
toThrift() - Method in class org.apache.accumulo.core.data.Mutation
Creates a TMutation object containing this Mutation's data.
toThrift() - Method in class org.apache.accumulo.core.data.Range
 
toThrift(Instance) - Method in class org.apache.accumulo.core.security.Credentials
Converts the current object to the relevant thrift type.
toTIteratorSetting(IteratorSetting) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
toZeroPaddedString(long, int, int, byte[]) - Static method in class org.apache.accumulo.core.util.FastFormat
 
toZeroPaddedString(byte[], int, long, int, int, byte[]) - Static method in class org.apache.accumulo.core.util.FastFormat
 
trace - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
TraceCommand - Class in org.apache.accumulo.core.util.shell.commands
 
TraceCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.TraceCommand
 
TraceDump - Class in org.apache.accumulo.core.trace
 
TraceDump() - Constructor for class org.apache.accumulo.core.trace.TraceDump
 
TraceDump.Printer - Interface in org.apache.accumulo.core.trace
 
TraceFormatter - Class in org.apache.accumulo.core.trace
A formatter than can be used in the shell to display trace information.
TraceFormatter() - Constructor for class org.apache.accumulo.core.trace.TraceFormatter
 
TRange - Class in org.apache.accumulo.core.data.thrift
 
TRange() - Constructor for class org.apache.accumulo.core.data.thrift.TRange
 
TRange(TKey, TKey, boolean, boolean, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.thrift.TRange
 
TRange(TRange) - Constructor for class org.apache.accumulo.core.data.thrift.TRange
Performs a deep copy on other.
TRange._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
transform(Key) - Method in class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
 
transform(Range) - Method in class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
 
transform(Key) - Method in class org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor
 
transform(Range) - Method in class org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor
 
transform(Range) - Method in interface org.apache.accumulo.core.file.keyfunctor.KeyFunctor
Implementations should return null if a range can not be converted to a bloom key.
transform(Key) - Method in interface org.apache.accumulo.core.file.keyfunctor.KeyFunctor
 
transform(Key) - Method in class org.apache.accumulo.core.file.keyfunctor.RowFunctor
 
transform(Range) - Method in class org.apache.accumulo.core.file.keyfunctor.RowFunctor
 
TransformingIterator - Class in org.apache.accumulo.core.iterators.user
The TransformingIterator allows portions of a key (except for the row) to be transformed.
TransformingIterator() - Constructor for class org.apache.accumulo.core.iterators.user.TransformingIterator
 
TransformingIterator.KVBuffer - Interface in org.apache.accumulo.core.iterators.user
 
transformKeys() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Reads all keys matching the first key's prefix from the source iterator, transforms them, and sorts the resulting keys.
transformRange(SortedKeyValueIterator<Key, Value>, TransformingIterator.KVBuffer) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Transforms input.
translate(Column) - Method in class org.apache.accumulo.core.client.impl.Translator.ColumnTranslator
 
translate(ConstraintViolationSummary) - Method in class org.apache.accumulo.core.client.impl.Translator.CVSTranslator
 
translate(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.Translator.KeyExtentTranslator
 
translate(List<IT>) - Method in class org.apache.accumulo.core.client.impl.Translator.ListTranslator
 
translate(Range) - Method in class org.apache.accumulo.core.client.impl.Translator.RangeTranslator
 
translate(TColumn) - Method in class org.apache.accumulo.core.client.impl.Translator.TColumnTranslator
 
translate(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.client.impl.Translator.TCVSTranslator
 
translate(TKeyExtent) - Method in class org.apache.accumulo.core.client.impl.Translator.TKeyExtentTranslator
 
translate(TRange) - Method in class org.apache.accumulo.core.client.impl.Translator.TRangeTranslator
 
translate(IT) - Method in class org.apache.accumulo.core.client.impl.Translator
 
translate(Map<IKT, T>, Translator<IKT, OKT>) - Static method in class org.apache.accumulo.core.client.impl.Translator
 
translate(Map<IKT, IVT>, Translator<IKT, OKT>, Translator<IVT, OVT>) - Static method in class org.apache.accumulo.core.client.impl.Translator
 
translate(Collection<IT>, Translator<IT, OT>) - Static method in class org.apache.accumulo.core.client.impl.Translator
 
Translator<IT,OT> - Class in org.apache.accumulo.core.client.impl
 
Translator() - Constructor for class org.apache.accumulo.core.client.impl.Translator
 
Translator.ColumnTranslator - Class in org.apache.accumulo.core.client.impl
 
Translator.ColumnTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.ColumnTranslator
 
Translator.CVSTranslator - Class in org.apache.accumulo.core.client.impl
 
Translator.CVSTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.CVSTranslator
 
Translator.KeyExtentTranslator - Class in org.apache.accumulo.core.client.impl
 
Translator.KeyExtentTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.KeyExtentTranslator
 
Translator.ListTranslator<IT,OT> - Class in org.apache.accumulo.core.client.impl
 
Translator.ListTranslator(Translator<IT, OT>) - Constructor for class org.apache.accumulo.core.client.impl.Translator.ListTranslator
 
Translator.RangeTranslator - Class in org.apache.accumulo.core.client.impl
 
Translator.RangeTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.RangeTranslator
 
Translator.TColumnTranslator - Class in org.apache.accumulo.core.client.impl
 
Translator.TColumnTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.TColumnTranslator
 
Translator.TCVSTranslator - Class in org.apache.accumulo.core.client.impl
 
Translator.TCVSTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.TCVSTranslator
 
Translator.TKeyExtentTranslator - Class in org.apache.accumulo.core.client.impl
 
Translator.TKeyExtentTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.TKeyExtentTranslator
 
Translator.TRangeTranslator - Class in org.apache.accumulo.core.client.impl
 
Translator.TRangeTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.TRangeTranslator
 
Translators - Class in org.apache.accumulo.core.client.impl
 
Translators() - Constructor for class org.apache.accumulo.core.client.impl.Translators
 
transportFactory() - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
transportFactory(int) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
transportFactory(long) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
TREEMAP - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for TreeMap
TRT - Static variable in class org.apache.accumulo.core.client.impl.Translators
 
truncate(Text, int) - Static method in class org.apache.accumulo.core.util.TextUtil
 
truncate(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
ts - Variable in class org.apache.accumulo.core.data.thrift.TCondition
 
tServerInfo - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
tserverLock - Variable in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
TTimeoutTransport - Class in org.apache.accumulo.core.util
 
TTimeoutTransport() - Constructor for class org.apache.accumulo.core.util.TTimeoutTransport
 
ttl - Variable in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
type(KeyExtent) - Static method in enum org.apache.accumulo.core.client.impl.TabletType
 
type(Collection<KeyExtent>) - Static method in enum org.apache.accumulo.core.client.impl.TabletType
 
type - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
type - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
TYPE - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
type - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
type - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
typedReduce(Key, Iterator<V>) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Reduces a list of V into a single V.
typedReduce(Key, Iterator<BigDecimal>) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalMaxCombiner
 
typedReduce(Key, Iterator<BigDecimal>) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalMinCombiner
 
typedReduce(Key, Iterator<BigDecimal>) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalSummingCombiner
 
typedReduce(Key, Iterator<Long>) - Method in class org.apache.accumulo.core.iterators.user.MaxCombiner
 
typedReduce(Key, Iterator<Long>) - Method in class org.apache.accumulo.core.iterators.user.MinCombiner
 
typedReduce(Key, Iterator<List<Long>>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
typedReduce(Key, Iterator<Long>) - Method in class org.apache.accumulo.core.iterators.user.SummingCombiner
 
TypedValueCombiner<V> - Class in org.apache.accumulo.core.iterators
A Combiner that decodes each Value to type V before reducing, then encodes the result of typedReduce back to Value.
TypedValueCombiner() - Constructor for class org.apache.accumulo.core.iterators.TypedValueCombiner
 
TypedValueCombiner.Encoder<V> - Interface in org.apache.accumulo.core.iterators
An interface for translating from byte[] to V and back.

U

UIntegerLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for an unsigned integer.
UIntegerLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
 
ULongLexicoder - Class in org.apache.accumulo.core.client.lexicoder
Unsigned long lexicoder.
ULongLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
 
unassignedTablets - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unescape(byte[]) - Static method in class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
Unescapes 0x00 0x01 0x01 with 0x00 and 0x01 0x01 0x2 with 0x01
unloadTablet(TInfo, TCredentials, String, TKeyExtent, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
unloadTablet(TInfo, TCredentials, String, TKeyExtent, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
unloadTablet(TInfo, TCredentials, String, TKeyExtent, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
unloadTablet(TInfo, TCredentials, String, TKeyExtent, boolean) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
unnamedOptionDescriptions - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
unsetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetArguments() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
unsetAuthorizationFailures() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetAutoClean() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
unsetBadTServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetBatch() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
unsetBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetCf() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
unsetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
unsetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
unsetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
unsetClassName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
unsetClient() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetCmid() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
unsetCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
unsetColFamily() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
unsetColQualifier() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
unsetColumnFamily() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
unsetColumnQualifier() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
unsetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
unsetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetColumnVisibility() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
unsetColVisibility() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
unsetConditions() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
unsetConstrainClass() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
unsetCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetCq() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
unsetCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetCv() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
unsetCve() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
unsetData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
unsetDataCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetDataCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetDeadTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetDescription() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
unsetElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
unsetEndRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
unsetEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
unsetEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
unsetEntries() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
unsetEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetErrorDir() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
unsetErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetEstimatedSize() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
unsetEx() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
unsetFail() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetFailedExtents() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
unsetFailures() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
unsetFilenames() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
unsetFiles() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
unsetFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
unsetFinished() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetFlushID() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
unsetForce() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
unsetFullScans() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
unsetGoalState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetHasTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
unsetHoldTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
unsetIdleTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetIndexCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetIndexCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetInfiniteStartKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
unsetInfiniteStopKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
unsetIngestByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetIngestRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetIngestRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetInputFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetInstanceId() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
unsetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
unsetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
unsetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
unsetInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetIsolated() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetIteratorClass() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
unsetIterators() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
unsetIterators() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
unsetIterName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
unsetKey() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
unsetKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
unsetKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
unsetLast() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetLastContact() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetLastStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
unsetLocalityGroup() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
unsetLogSorts() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetLookups() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetMajors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetMajors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetMaxLoops() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
unsetMinors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetMinors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetMore() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
unsetMore() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
unsetMutation() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
unsetMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
unsetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
unsetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
unsetName() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
unsetName() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
unsetNamespaceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
unsetNewTablets() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
unsetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
unsetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
unsetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
unsetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
unsetNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
unsetNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
unsetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
unsetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
unsetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
unsetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
unsetNum() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
unsetNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetOldTablet() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
unsetOnlineTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetOp() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
unsetOp() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
unsetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
unsetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
unsetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
unsetOptions() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
unsetOsLoad() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetPartNextKey() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
unsetPartNextKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
unsetPartScan() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
unsetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
unsetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
unsetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
unsetPrevEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
unsetPriority() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
unsetPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
unsetProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
unsetProperties() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
unsetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
unsetQueryByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetQueryRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetQueryRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetQueued() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
unsetQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetRange() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetReadaheadThreshold() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetReason() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetRecs() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetRecsInMemory() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetResult() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
unsetResult() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
unsetResults() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
unsetResults() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
unsetRow() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
unsetRow() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
unsetRunning() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
unsetRuntime() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
unsetSave() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
unsetScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
unsetScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
unsetScanId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
unsetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
unsetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
unsetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
unsetScanRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetScans() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
unsetServer() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
unsetServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
unsetServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
unsetServersShuttingDown() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
unsetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
unsetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
unsetSessionId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
unsetSetTime() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
unsetSetTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
unsetSplit() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
unsetSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
unsetSplits() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
unsetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
unsetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetStart() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
unsetStarted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetStartKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
unsetStartRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
unsetStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
unsetStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
unsetState() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
unsetState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetState() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetStatus() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
unsetStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
unsetStatus() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
unsetStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetStop() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
unsetStopKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
unsetStopTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
unsetSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetSymbols() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
unsetSysPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
unsetTable() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
unsetTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
unsetTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
unsetTableId() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
unsetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
unsetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
unsetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
unsetTableID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
unsetTableMap() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetTableMap() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
unsetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
unsetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
unsetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
unsetTableName() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
unsetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
unsetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
unsetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
unsetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
unsetTables() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
unsetTables() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
unsetTablet() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
unsetTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetTabletServer() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
unsetTblNspcPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
unsetTblPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
unsetTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
unsetTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
unsetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
unsetTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
unsetTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
unsetTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
unsetToAuth() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
unsetToe() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
unsetToken() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
unsetTokenClassName() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
unsetTs() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
unsetTServerInfo() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetTserverLock() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
unsetTtl() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
unsetType() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
unsetType() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
unsetType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetUnassignedTablets() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
unsetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
unsetUsage() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
unsetUser() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
unsetUser() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetVal() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
unsetValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
unsetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
unsetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
unsetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
unsetValues() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
unsetViolationCode() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
unsetViolationDescription() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
unsetViolationSummaries() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
unsetViolationSummaries() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
unsetWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
unsetWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetWhy() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
UnsynchronizedBuffer - Class in org.apache.accumulo.core.util
 
UnsynchronizedBuffer() - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer
 
UnsynchronizedBuffer.Reader - Class in org.apache.accumulo.core.util
 
UnsynchronizedBuffer.Reader(byte[]) - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
 
UnsynchronizedBuffer.Reader(ByteBuffer) - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
 
UnsynchronizedBuffer.Writer - Class in org.apache.accumulo.core.util
 
UnsynchronizedBuffer.Writer() - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 
UnsynchronizedBuffer.Writer(int) - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 
untransformColumnFamilies(Collection<ByteSequence>) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Reverses the transformation applied to column families that are fetched at seek time.
update(Mutation) - Method in class org.apache.accumulo.core.client.impl.Writer
 
update(TInfo, TCredentials, TKeyExtent, TMutation, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
update(TInfo, TCredentials, TKeyExtent, TMutation, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
update(TInfo, TCredentials, TKeyExtent, TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
update(TInfo, TCredentials, TKeyExtent, TMutation) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
updateBinningStats(int, long, Map<String, TabletLocator.TabletServerMutations<Mutation>>) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
 
UpdateErrors - Class in org.apache.accumulo.core.data.thrift
 
UpdateErrors() - Constructor for class org.apache.accumulo.core.data.thrift.UpdateErrors
 
UpdateErrors(Map<TKeyExtent, Long>, List<TConstraintViolationSummary>, Map<TKeyExtent, SecurityErrorCode>) - Constructor for class org.apache.accumulo.core.data.thrift.UpdateErrors
 
UpdateErrors(UpdateErrors) - Constructor for class org.apache.accumulo.core.data.thrift.UpdateErrors
Performs a deep copy on other.
UpdateErrors._Fields - Enum in org.apache.accumulo.core.data.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
updateID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
updateID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
updateScanIteratorOption(String, String, String) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Override any existing options on the given named iterator
updateScanIteratorOption(String, String, String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Update the options for an iterator.
updateUser(String, AuthenticationToken) - Method in class org.apache.accumulo.core.util.shell.Shell
 
upperBound(List<? extends T>, T, Comparator<? super T>) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Upper bound binary search.
upperBound(List<? extends Comparable<? super T>>, T) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Upper bound binary search.
usage - Variable in class org.apache.accumulo.core.client.admin.DiskUsage
 
usage - Variable in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.AddSplitsCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.AuthenticateCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.CloneTableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.ConstraintCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.CreateNamespaceCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.CreateTableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.CreateUserCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.DebugCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.DeleteCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.DropUserCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.DUCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.EGrepCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.ExecfileCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.ExportTableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.FateCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.GrantCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.GrepCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.HelpCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.ImportDirectoryCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.ImportTableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.InsertCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.RenameNamespaceCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.RenameTableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.RevokeCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.SetGroupsCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.SleepCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.TableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.TableOperation
 
usage() - Method in class org.apache.accumulo.core.util.shell.commands.UserCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
useJsse() - Method in class org.apache.accumulo.core.util.SslConnectionParams
 
user - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
user - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
USER_ACCUMULO_DIR_NAME - Static variable in class org.apache.accumulo.core.client.ClientConfiguration
 
USER_CONF_FILENAME - Static variable in class org.apache.accumulo.core.client.ClientConfiguration
 
UserCommand - Class in org.apache.accumulo.core.util.shell.commands
 
UserCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.UserCommand
 
username - Variable in class org.apache.accumulo.core.trace.InstanceUserPassword
 
userOption - Static variable in class org.apache.accumulo.core.util.shell.ShellOptions
 
UserPermissionsCommand - Class in org.apache.accumulo.core.util.shell.commands
 
UserPermissionsCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.UserPermissionsCommand
 
UsersCommand - Class in org.apache.accumulo.core.util.shell.commands
 
UsersCommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.UsersCommand
 
usesLocalIterators(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Determines whether a configuration uses local iterators.
usesLocalIterators(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Determines whether a configuration uses local iterators.
usesLocalIterators(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Determines whether a configuration uses local iterators.
usesLocalIterators(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
usesLocalIterators() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
useSsl() - Method in class org.apache.accumulo.core.util.shell.ShellOptionsJC
 
UTF8 - Static variable in class org.apache.accumulo.core.Constants
Deprecated.
since 1.5.3, 1.6.2; statically import Guava's Charsets.UTF_8 or Java 7's built-in StandardCharsets.UTF_8 or use Charset.forName(String) with "UTF-8" instead
Utils - Class in org.apache.accumulo.core.file.rfile.bcfile
Supporting Utility classes used by TFile, and shared by users of TFile.
Utils.Version - Class in org.apache.accumulo.core.file.rfile.bcfile
A generic Version class.
Utils.Version(DataInput) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Construct the Version object by reading from the input stream.
Utils.Version(short, short) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Constructor.
UtilWaitThread - Class in org.apache.accumulo.core.util
 
UtilWaitThread() - Constructor for class org.apache.accumulo.core.util.UtilWaitThread
 
UUIDLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for a UUID that maintains its lexicographic sorting order.
UUIDLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
 

V

val - Variable in class org.apache.accumulo.core.data.thrift.TCondition
 
VALID_ID - Static variable in class org.apache.accumulo.core.client.impl.Tables
 
VALID_ID_REGEX - Static variable in class org.apache.accumulo.core.client.impl.Tables
 
VALID_NAME - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
 
VALID_NAME - Static variable in class org.apache.accumulo.core.client.impl.Tables
 
VALID_NAME_REGEX - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
 
VALID_NAME_REGEX - Static variable in class org.apache.accumulo.core.client.impl.Tables
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
validate() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
validate() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
validate(Iterable<Map.Entry<String, String>>) - Static method in class org.apache.accumulo.core.conf.ConfigSanityCheck
Validates the given configuration entries.
validate() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
validate() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
validate() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
validate() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
validate() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
validate() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
validate() - Method in class org.apache.accumulo.core.data.thrift.TRange
 
validate() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
validate(String, String) - Method in class org.apache.accumulo.core.file.rfile.CreateEmpty.IsSupportedCompressionAlgorithm
 
validate(String, String) - Method in class org.apache.accumulo.core.file.rfile.CreateEmpty.NamedLikeRFile
 
validate() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
validate() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
validate() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
validate() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
validate() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
validate() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
validate() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
validate() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
validate() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
validate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
validate() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
validate() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
validate() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
validate(T) - Method in class org.apache.accumulo.core.util.ArgumentChecker.Validator
 
validateOptions(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Check whether a configuration is fully configured to be used with an Accumulo InputFormat.
validateOptions(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Check whether a configuration is fully configured to be used with an Accumulo InputFormat.
validateOptions(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
Check whether a configuration is fully configured to be used with an Accumulo InputFormat.
validateOptions(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
Deprecated.
since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
Deprecated.
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.Combiner
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.Filter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.LongCombiner
 
validateOptions(Map<String, String>) - Method in interface org.apache.accumulo.core.iterators.OptionDescriber
Check to see if an options map contains all options required by an iterator and that the option values are in the expected formats.
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
value - Variable in class org.apache.accumulo.core.cli.ClientOpts.Password
 
value - Variable in class org.apache.accumulo.core.data.thrift.TKeyValue
 
Value - Class in org.apache.accumulo.core.data
A byte sequence that is usable as a key or value.
Value() - Constructor for class org.apache.accumulo.core.data.Value
Create a zero-size sequence.
Value(byte[]) - Constructor for class org.apache.accumulo.core.data.Value
Create a Value using the byte array as the initial value.
Value(ByteBuffer) - Constructor for class org.apache.accumulo.core.data.Value
Create a Value using a copy of the ByteBuffer's content.
Value(ByteBuffer, boolean) - Constructor for class org.apache.accumulo.core.data.Value
Deprecated.
A copy of the bytes in the buffer is always made. Use Value.Value(ByteBuffer) instead.
Value(byte[], boolean) - Constructor for class org.apache.accumulo.core.data.Value
Create a Value based on the given bytes.
Value(Value) - Constructor for class org.apache.accumulo.core.data.Value
Set the new Value to a copy of the contents of the passed ibw.
Value(byte[], int, int) - Constructor for class org.apache.accumulo.core.data.Value
Set the value to a copy of the given byte range
value - Variable in class org.apache.accumulo.core.data.Value
 
value - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
value - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
value - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
value - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
Value.Comparator - Class in org.apache.accumulo.core.data
A Comparator optimized for Value.
Value.Comparator() - Constructor for class org.apache.accumulo.core.data.Value.Comparator
constructor
VALUE_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
ValueFormatException - Exception in org.apache.accumulo.core.iterators
Exception used for TypedValueCombiner and it's Encoders decode() function
ValueFormatException(String) - Constructor for exception org.apache.accumulo.core.iterators.ValueFormatException
 
ValueFormatException(Exception) - Constructor for exception org.apache.accumulo.core.iterators.ValueFormatException
 
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ScanState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ScanType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.TimeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.ConditionalWriter.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.TabletType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ConfigurationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TableOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.ConnectorInfo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.GeneralOpts
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.InstanceOpts
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.TokenSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator.Opts
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.Features
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.ScanOpts
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator.Features
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator.WriteOpts
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase.ConnectorInfo
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase.GeneralOpts
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase.InstanceOpts
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator.Opts
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator.Features
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator.ScanOpts
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator.Features
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator.WriteOpts
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.security.SecurityErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.conf.Property
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.conf.PropertyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.Mutation.SERIALIZED_FORMAT
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.PartialKey
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TCMStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.iterators.LongCombiner.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.iterators.user.SummingArrayCombiner.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.state.tables.TableState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterGoalState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.TabletLoadState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.ColumnVisibility.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.SystemPermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.TablePermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.util.ServerServices.Service
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.util.shell.commands.OptUtil.AdlOpt
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.util.shell.Shell.Command.CompletionSet
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.util.shell.ShellCommandException.ErrorCode
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.ScanState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.ScanType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.TimeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.ConditionalWriter.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.TabletType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ConfigurationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.TableOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.ConnectorInfo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.GeneralOpts
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.InstanceOpts
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.TokenSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator.Opts
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.Features
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.ScanOpts
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator.Features
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator.WriteOpts
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase.ConnectorInfo
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase.GeneralOpts
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase.InstanceOpts
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator.Opts
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator.Features
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator.ScanOpts
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator.Features
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator.WriteOpts
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.security.SecurityErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
values() - Static method in enum org.apache.accumulo.core.conf.Property
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.conf.PropertyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.Mutation.SERIALIZED_FORMAT
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.PartialKey
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TCMStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.accumulo.core.data.thrift.TMutation
 
values() - Static method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.iterators.LongCombiner.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.iterators.user.SummingArrayCombiner.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.state.tables.TableState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterGoalState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.MasterState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.TabletLoadState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.ColumnVisibility.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.SystemPermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.TablePermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.accumulo.core.util.MapCounter
 
values() - Static method in enum org.apache.accumulo.core.util.ServerServices.Service
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.util.shell.commands.OptUtil.AdlOpt
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.util.shell.Shell.Command.CompletionSet
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.util.shell.ShellCommandException.ErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
VAR_LEN_ENCODER - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
VAR_LONG_ARRAY_ENCODER - Static variable in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
ve - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
vectorSize - Variable in class org.apache.accumulo.core.bloomfilter.Filter
The vector size of this filter.
verbose - Variable in class org.apache.accumulo.core.util.shell.Shell
 
VERSION - Static variable in class org.apache.accumulo.core.Constants
 
VERSION - Static variable in class org.apache.accumulo.core.FilteredConstants
 
Version - Class in org.apache.accumulo.core.util
 
Version(String) - Constructor for class org.apache.accumulo.core.util.Version
 
VersioningIterator - Class in org.apache.accumulo.core.iterators.user
 
VersioningIterator() - Constructor for class org.apache.accumulo.core.iterators.user.VersioningIterator
 
VersioningIterator - Class in org.apache.accumulo.core.iterators
Deprecated.
since 1.4, replaced by VersioningIterator
VersioningIterator() - Constructor for class org.apache.accumulo.core.iterators.VersioningIterator
Deprecated.
 
VersioningIterator(SortedKeyValueIterator<Key, Value>, int) - Constructor for class org.apache.accumulo.core.iterators.VersioningIterator
Deprecated.
 
violationCode - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
violationCode - Variable in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
violationDescription - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
violationDescription - Variable in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
Violations - Class in org.apache.accumulo.core.constraints
 
Violations() - Constructor for class org.apache.accumulo.core.constraints.Violations
 
violationSummaries - Variable in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
violationSummaries - Variable in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
VisibilityConstraint - Class in org.apache.accumulo.core.security
A constraint that checks the visibility of columns against the actor's authorizations.
VisibilityConstraint() - Constructor for class org.apache.accumulo.core.security.VisibilityConstraint
 
VisibilityEvaluator - Class in org.apache.accumulo.core.security
A class which evaluates visibility expressions against a set of authorizations.
VisibilityEvaluator(Authorizations) - Constructor for class org.apache.accumulo.core.security.VisibilityEvaluator
Creates a new evaluator for the given collection of authorizations.
VisibilityFilter - Class in org.apache.accumulo.core.iterators.system
 
VisibilityFilter() - Constructor for class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
VisibilityFilter(SortedKeyValueIterator<Key, Value>, Authorizations, byte[]) - Constructor for class org.apache.accumulo.core.iterators.system.VisibilityFilter
 
VisibilityFilter - Class in org.apache.accumulo.core.iterators.user
 
VisibilityFilter() - Constructor for class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
VisibilityParseException - Exception in org.apache.accumulo.core.security
An exception thrown when a visibility string cannot be parsed.
VisibilityParseException(String, byte[], int) - Constructor for exception org.apache.accumulo.core.security.VisibilityParseException
Creates a new exception.
visit(SpanTreeVisitor) - Method in class org.apache.accumulo.core.trace.SpanTree
 
visit(int, RemoteSpan, RemoteSpan, Collection<RemoteSpan>) - Method in interface org.apache.accumulo.core.trace.SpanTreeVisitor
 
Volume - Interface in org.apache.accumulo.core.volume
Encapsulates a FileSystem and a base Path within that filesystem.
VolumeConfiguration - Class in org.apache.accumulo.core.volume
 
VolumeConfiguration() - Constructor for class org.apache.accumulo.core.volume.VolumeConfiguration
 
VolumeImpl - Class in org.apache.accumulo.core.volume
Basic Volume implementation that contains a FileSystem and a base path that should be used within that filesystem.
VolumeImpl(Path, Configuration) - Constructor for class org.apache.accumulo.core.volume.VolumeImpl
 
VolumeImpl(FileSystem, String) - Constructor for class org.apache.accumulo.core.volume.VolumeImpl
 

W

waitForFateOperation(TInfo, TCredentials, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient
 
waitForFateOperation(TInfo, TCredentials, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.FateService.AsyncIface
 
waitForFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
 
waitForFateOperation(TInfo, TCredentials, long) - Method in interface org.apache.accumulo.core.master.thrift.FateService.Iface
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
waitForWrites - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
waitForWrites - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
whoami() - Method in class org.apache.accumulo.core.client.Connector
Get the current user for this connector
whoami() - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
 
whoami() - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
WhoAmICommand - Class in org.apache.accumulo.core.util.shell.commands
 
WhoAmICommand() - Constructor for class org.apache.accumulo.core.util.shell.commands.WhoAmICommand
 
WholeColumnFamilyIterator - Class in org.apache.accumulo.core.iterators.user
The WholeColumnFamilyIterator is designed to provide row/cf-isolation so that queries see mutations as atomic.
WholeColumnFamilyIterator() - Constructor for class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
WholeRowIterator - Class in org.apache.accumulo.core.iterators.user
The WholeRowIterator is designed to provide row-isolation so that queries see mutations as atomic.
WholeRowIterator() - Constructor for class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
WholeRowIterator - Class in org.apache.accumulo.core.iterators
Deprecated.
since 1.4, replaced by WholeRowIterator
WholeRowIterator() - Constructor for class org.apache.accumulo.core.iterators.WholeRowIterator
Deprecated.
 
why - Variable in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
with(ClientConfiguration.ClientProperty, String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.setProperty(ClientProperty, String) but returns the ClientConfiguration for chaining purposes
withInstance(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.with(ClientProperty, String) for ClientProperty.INSTANCE_NAME
withInstance(UUID) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.with(ClientProperty, String) for ClientProperty.INSTANCE_ID
withKeystore(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.withKeystore(String, String, String) with password null and type null
withKeystore(String, String, String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.with(ClientProperty, String) for ClientProperty.INSTANCE_RPC_SSL_CLIENT_AUTH, ClientProperty.RPC_SSL_KEYSTORE_PATH, ClientProperty.RPC_SSL_KEYSTORE_PASSWORD, and ClientProperty.RPC_SSL_KEYSTORE_TYPE
withSsl(boolean) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.withSsl(boolean, boolean) with useJsseConfig set to false
withSsl(boolean, boolean) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.with(ClientProperty, String) for ClientProperty.INSTANCE_RPC_SSL_ENABLED and ClientProperty.RPC_USE_JSSE
withTruststore(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.withTruststore(String) with password null and type null
withTruststore(String, String, String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.with(ClientProperty, String) for ClientProperty.RPC_SSL_TRUSTORE_PATH, ClientProperty.RPC_SSL_TRUSTORE_PASSWORD, and ClientProperty.RPC_SSL_TRUSTORE_TYPE
withZkHosts(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.with(ClientProperty, String) for ClientProperty.INSTANCE_ZK_HOST
withZkTimeout(int) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Same as ClientConfiguration.with(ClientProperty, String) for ClientProperty.INSTANCE_ZK_TIMEOUT
WrappingIterator - Class in org.apache.accumulo.core.iterators
A convenience class for implementing iterators that select, but do not modify, entries read from a source iterator.
WrappingIterator() - Constructor for class org.apache.accumulo.core.iterators.WrappingIterator
 
write(DataOutput) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
write(DataOutput) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
write(DataOutput) - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
write(Iterator<ConditionalMutation>) - Method in interface org.apache.accumulo.core.client.ConditionalWriter
This method returns one result for each mutation passed to it.
write(ConditionalMutation) - Method in interface org.apache.accumulo.core.client.ConditionalWriter
This method has the same thread safety guarantees as @link ConditionalWriter.write(Iterator)
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
 
write(TProtocol) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
 
write(TProtocol) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.IteratorSetting
 
write(int) - Method in class org.apache.accumulo.core.client.lexicoder.impl.FixedByteArrayOutputStream
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.impl.FixedByteArrayOutputStream
 
write(Text, Mutation) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
Push a mutation into a table.
write(Text, Mutation) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
Push a mutation into a table.
write(DataOutput) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Writes the state for the current object out to the specified DataOutput
write(DataOutput) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Column
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Key
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.KeyExtent
Writes this extent's data fields to a DataOutput object
write(DataOutput) - Method in class org.apache.accumulo.core.data.Mutation
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Range
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TCondition
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
write(TProtocol) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Value
 
write(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Write the object to a DataOutput.
write(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
write(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
write(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
write(DataOutputStream, V) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
write(DataOutputStream, Long) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.FixedLongArrayEncoder
 
write(DataOutputStream, Long) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.VarLongArrayEncoder
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
write(TProtocol) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
write(int) - Method in class org.apache.accumulo.core.security.crypto.BlockedOutputStream
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.security.crypto.BlockedOutputStream
 
write(byte[]) - Method in class org.apache.accumulo.core.security.crypto.BlockedOutputStream
 
write(TProtocol) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticateUser_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.bulkImportFiles_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeAuthorizations_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkClass_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkTableClass_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.createLocalUser_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.dropLocalUser_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getConfiguration_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getDiskUsage_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getInstanceId_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getTableConfiguration_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getZooKeepers_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantSystemPermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantTablePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasSystemPermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasTablePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.isActive_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.listLocalUsers_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.ping_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeTablePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.fails_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.success_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.throwsError_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.beginFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.executeFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.finishFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.waitForFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getMasterStats_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.initiateFlush_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeNamespaceProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeSystemProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeTableProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.reportSplitExtent_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.reportTabletStatus_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setMasterGoalState_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setNamespaceProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setSystemProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setTableProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.shutdown_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.shutdownTabletServer_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.waitForFlush_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.applyUpdates_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.bulkImport_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.chop_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeConditionalUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeMultiScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compact_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.conditionalUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueMultiScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.fastHalt_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flush_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flushTablet_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveCompactions_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveScans_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getHistoricalStats_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletServerStatus_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletStats_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.halt_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.invalidateConditionalUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.loadTablet_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.removeLogs_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.splitTablet_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startConditionalUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startMultiScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.unloadTablet_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.update_call
 
writeMessageBegin(TMessage) - Method in class org.apache.accumulo.core.util.ThriftUtil.TraceProtocol
 
writeMessageEnd() - Method in class org.apache.accumulo.core.util.ThriftUtil.TraceProtocol
 
Writer - Class in org.apache.accumulo.core.client.impl
 
Writer(Instance, Credentials, Text) - Constructor for class org.apache.accumulo.core.client.impl.Writer
 
Writer(Instance, Credentials, String) - Constructor for class org.apache.accumulo.core.client.impl.Writer
 
writer - Variable in class org.apache.accumulo.core.client.mock.MockShell
Deprecated.
since 1.6.0; use out
writeString(DataOutput, String) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Write a String as a VInt n, followed by n Bytes as in Text format.
writeVInt(DataOutput, int) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Encoding an integer into a variable-length encoding format.
writeVInt(int) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 
writeVLong(DataOutput, long) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Encoding a Long integer into a variable-length encoding format.
writeVLong(long) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 

X

xor(Filter) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
xor(Filter) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
xor(Filter) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Peforms a logical XOR between this filter and a specified filter.

Z

ZBULK_FAILED_COPYQ - Static variable in class org.apache.accumulo.core.Constants
 
ZCONFIG - Static variable in class org.apache.accumulo.core.Constants
 
ZDEAD - Static variable in class org.apache.accumulo.core.Constants
 
ZDEADTSERVERS - Static variable in class org.apache.accumulo.core.Constants
 
ZFATE - Static variable in class org.apache.accumulo.core.Constants
 
ZGC - Static variable in class org.apache.accumulo.core.Constants
 
ZGC_LOCK - Static variable in class org.apache.accumulo.core.Constants
 
ZHDFS_RESERVATIONS - Static variable in class org.apache.accumulo.core.Constants
 
ZINSTANCES - Static variable in class org.apache.accumulo.core.Constants
 
ZMASTER_GOAL_STATE - Static variable in class org.apache.accumulo.core.Constants
 
ZMASTER_LOCK - Static variable in class org.apache.accumulo.core.Constants
 
ZMASTERS - Static variable in class org.apache.accumulo.core.Constants
 
ZMONITOR - Static variable in class org.apache.accumulo.core.Constants
 
ZMONITOR_HTTP_ADDR - Static variable in class org.apache.accumulo.core.Constants
 
ZMONITOR_LOCK - Static variable in class org.apache.accumulo.core.Constants
 
ZMONITOR_LOG4J_ADDR - Static variable in class org.apache.accumulo.core.Constants
 
ZNAMESPACE_CONF - Static variable in class org.apache.accumulo.core.Constants
 
ZNAMESPACE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
ZNAMESPACES - Static variable in class org.apache.accumulo.core.Constants
 
ZNEXT_FILE - Static variable in class org.apache.accumulo.core.Constants
 
ZooKeeperInstance - Class in org.apache.accumulo.core.client
An implementation of instance that looks in zookeeper to find information needed to connect to an instance of accumulo.
ZooKeeperInstance(String, String) - Constructor for class org.apache.accumulo.core.client.ZooKeeperInstance
 
ZooKeeperInstance(String, String, int) - Constructor for class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
ZooKeeperInstance(UUID, String) - Constructor for class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
ZooKeeperInstance(UUID, String, int) - Constructor for class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
ZooKeeperInstance(Configuration) - Constructor for class org.apache.accumulo.core.client.ZooKeeperInstance
 
ZookeeperLockChecker - Class in org.apache.accumulo.core.client.impl
 
zookeepers - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
ZooTraceClient - Class in org.apache.accumulo.core.trace
Find a Span collector via zookeeper and push spans there via Thrift RPC
ZooTraceClient(ZooReader, String, String, String, long, int) - Constructor for class org.apache.accumulo.core.trace.ZooTraceClient
 
ZooUtil - Class in org.apache.accumulo.core.zookeeper
 
ZooUtil() - Constructor for class org.apache.accumulo.core.zookeeper.ZooUtil
 
ZPROBLEMS - Static variable in class org.apache.accumulo.core.Constants
 
ZRECOVERY - Static variable in class org.apache.accumulo.core.Constants
 
ZROOT - Static variable in class org.apache.accumulo.core.Constants
 
ZROOT_TABLET - Static variable in class org.apache.accumulo.core.metadata.RootTable
ZK path relative to the instance directory for information about the root tablet
ZROOT_TABLET_FUTURE_LOCATION - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
ZROOT_TABLET_LAST_LOCATION - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
ZROOT_TABLET_LOCATION - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
ZROOT_TABLET_PATH - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
ZROOT_TABLET_WALOGS - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
ZTABLE_COMPACT_CANCEL_ID - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_COMPACT_ID - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_CONF - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_FLUSH_ID - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_LOCKS - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_NAMESPACE - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_STATE - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLES - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLES_INITIAL_ID - Static variable in class org.apache.accumulo.core.Constants
 
ZTRACERS - Static variable in class org.apache.accumulo.core.Constants
 
ZTSERVERS - Static variable in class org.apache.accumulo.core.Constants
 

_

_getTableId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
_locateTablet(Credentials, Text, boolean, boolean, boolean, TabletLocatorImpl.LockCheckerSession) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 

Copyright © 2011–2016 The Apache Software Foundation. All rights reserved.