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
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.filter.AgeOffFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.filter.ColumnAgeOffFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.filter.ColumnQualifierFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.filter.DeleteFilter
 
accept(Key, Value) - Method in interface org.apache.accumulo.core.iterators.filter.Filter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.filter.NoLabelFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.filter.RegExFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.filter.VisibilityFilter
 
access(long) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
Block has been accessed.
AccumuloConfiguration - Class in org.apache.accumulo.core.conf
 
AccumuloConfiguration() - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration
 
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.mapreduce
This class allows MapReduce jobs to use the Accumulo data file format for output of data The user must specify the output path that does not exist following via static method calls to this class: AccumuloFileOutputFormat.setOutputPath(job, outputDirectory) Other methods from FileOutputFormat to configure options are ignored Compression is using the DefaultCodec and is always on
AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
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
 
AccumuloInputFormat.RangeInputSplit - Class in org.apache.accumulo.core.client.mapreduce
The Class RangeInputSplit.
AccumuloInputFormat.RangeInputSplit() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat.RangeInputSplit
 
AccumuloInputFormat.RegexType - Enum in org.apache.accumulo.core.client.mapreduce
 
AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
This class allows MapReduce jobs to use Accumulo as the sink of data.
AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
AccumuloSecurityException - Exception in org.apache.accumulo.core.client
An Accumulo Exception for security violations, authentication failures, authorization failures, etc.
AccumuloSecurityException(String, SecurityErrorCode, Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloSecurityException(String, SecurityErrorCode) - 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
 
acquiredLock() - Method in interface org.apache.accumulo.core.zookeeper.ZooLock.AsyncLockWatcher
 
AcquireNewTable - Class in org.apache.accumulo.core.util
create a new default tablet for the metadata table This assumes that all tables have only one mapfile - not really generally useful
AcquireNewTable() - Constructor for class org.apache.accumulo.core.util.AcquireNewTable
 
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.
ActiveScan - Class in org.apache.accumulo.core.client.admin
A class that contains information about an 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>>) - 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.
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(Text, VT) - Method in class org.apache.accumulo.core.client.impl.Trie
 
add(String, VT) - Method in class org.apache.accumulo.core.client.impl.Trie
 
add(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
 
add(Map.Entry<Key, Value>) - Method in interface org.apache.accumulo.core.client.IsolatedScanner.RowBuffer
 
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(ColumnVisibility.Node) - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
addAggregators(String, List<AggregatorConfiguration>) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
addAggregators(String, List<AggregatorConfiguration>) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
addAggregators(String, List<AggregatorConfiguration>) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
addAggregators(List<AggregatorConfiguration>) - Method in class org.apache.accumulo.core.client.mock.MockTable
 
addAggregators(String, List<AggregatorConfiguration>) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
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, Mutation) - 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
 
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.TableConfiguration
 
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
 
addSource(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.HeapIterator
 
addSource(SortedKeyValueIterator<Key, Value>, IteratorEnvironment, Text, boolean) - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
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
 
addSubcommand(Set<Token>) - Method in class org.apache.accumulo.core.util.shell.Token
 
addTerm(SortedKeyValueIterator<Key, Value>, Text, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
addToAuthorizationFailures(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
addToAuthorizations(byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
addToAuthorizations(byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
addToAuthorizations(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
addToAuthorizations(byte[]) - 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
 
addToFiles(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
addToFullScans(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
addToLoggers(LoggerStatus) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
addToLoggers(String) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
addToLoggers(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
addToMutations(TabletMutations) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
addToMutations(TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
addToNewTablets(TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
addToRecovery(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
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
 
addToSplitPoints(byte[]) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
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(byte[]) - 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.listUsers_result
 
addToSuccess(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
addToSuccess(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_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
 
addToTables(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
addToTServerInfo(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
addToValues(byte[]) - 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
 
advance() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Move the cursor to the next key-value pair.
advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
afterEndKey(Key) - Method in class org.apache.accumulo.core.data.Range
 
age - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
AgeOffFilter - Class in org.apache.accumulo.core.iterators.filter
 
AgeOffFilter() - Constructor for class org.apache.accumulo.core.iterators.filter.AgeOffFilter
 
aggregate() - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
 
aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
 
AggregatingIterator - Class in org.apache.accumulo.core.iterators
This iterator wraps another iterator.
AggregatingIterator() - Constructor for class org.apache.accumulo.core.iterators.AggregatingIterator
 
AggregatingIterator(SortedKeyValueIterator<Key, Value>, ColumnToClassMapping<Aggregator>) - Constructor for class org.apache.accumulo.core.iterators.AggregatingIterator
 
Aggregator - Interface in org.apache.accumulo.core.iterators.aggregation
 
AggregatorConfiguration - Class in org.apache.accumulo.core.iterators.aggregation.conf
 
AggregatorConfiguration(Text, String) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorConfiguration
 
AggregatorConfiguration(Text, Text, String) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorConfiguration
 
AggregatorSet - Class in org.apache.accumulo.core.iterators.aggregation.conf
 
AggregatorSet(Map<String, String>) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
 
AggregatorSet() - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
 
aggs - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
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.
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.
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(WritableComparable, Writable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Append a key/value pair to the map.
append(Writable, Writable) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Append a key/value pair.
append(Object, Object) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Append a key/value pair.
append(byte[], byte[]) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Writer
Adding a new key-value pair to the TFile.
append(byte[], int, int, byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Writer
Adding a new key-value pair to TFile.
append(Key, Value) - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
appendRaw(byte[], int, int, MySequenceFile.ValueBytes) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated.  
applyUpdate(TInfo, long, TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
applyUpdate(TInfo, long, TMutation) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
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
 
ARRAY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Array overhead
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
 
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
 
atEnd() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Is cursor at the end location?
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
attemptToFixMapFile(Configuration, FileSystem, String) - Static method in class org.apache.accumulo.core.file.map.MapFileUtil
Deprecated.  
authenticateUser(String, byte[]) - Method in class 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.admin.SecurityOperationsImpl
Verify a username/password combination is valid
authenticateUser(TInfo, AuthInfo, String, byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
authenticateUser(TInfo, AuthInfo, String, byte[]) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
authenticateUser(String, byte[]) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
AuthInfo - Class in org.apache.accumulo.core.security.thrift
 
AuthInfo() - Constructor for class org.apache.accumulo.core.security.thrift.AuthInfo
 
AuthInfo(String, byte[], String) - Constructor for class org.apache.accumulo.core.security.thrift.AuthInfo
 
AuthInfo(AuthInfo) - Constructor for class org.apache.accumulo.core.security.thrift.AuthInfo
Performs a deep copy on other.
AuthInfo._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.
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.client.impl.thrift.ClientService.createUser_args
 
Authorizations - Class in org.apache.accumulo.core.security
 
Authorizations(Collection<byte[]>) - Constructor for class org.apache.accumulo.core.security.Authorizations
 
Authorizations(byte[]) - Constructor for class org.apache.accumulo.core.security.Authorizations
 
Authorizations() - Constructor for class org.apache.accumulo.core.security.Authorizations
 
Authorizations(String...) - Constructor for class org.apache.accumulo.core.security.Authorizations
 
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.client.mock.MockScannerBase
 

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
 
batch - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
BatchDeleter - Interface in org.apache.accumulo.core.client
 
BatchScanner - Interface in org.apache.accumulo.core.client
Implementations of BatchScanner support efficient lookups of many ranges in accumulo.
batchSize - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
BatchWriter - Interface in org.apache.accumulo.core.client
Send Mutations to a single Table in Accumulo.
BatchWriterImpl - Class in org.apache.accumulo.core.client.impl
 
BatchWriterImpl(Instance, AuthInfo, String, long, long, int) - Constructor for class org.apache.accumulo.core.client.impl.BatchWriterImpl
 
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) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Constructor
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) - 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
 
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(List<Mutation>, Map<String, TabletLocator.TabletServerMutations>, List<Mutation>) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
binMutations(List<Mutation>, Map<String, TabletLocator.TabletServerMutations>, List<Mutation>) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
 
binMutations(List<Mutation>, Map<String, TabletLocator.TabletServerMutations>, List<Mutation>) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
binMutations(List<Mutation>, Map<String, TabletLocator.TabletServerMutations>, List<Mutation>) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
 
binRanges(List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
binRanges(List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
 
binRanges(List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
binRanges(List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
 
BlockCache - Interface in org.apache.accumulo.core.file.blockfile.cache
Block cache interface.
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.
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
 
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.
buildCommands() - Method in class org.apache.accumulo.core.util.shell.Shell.CommandFactory
 
buildCommandsFromXML(File) - Method in class org.apache.accumulo.core.util.shell.Shell.CommandFactory
 
buildDocKey() - Method in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
buildFollowingPartitionKey(Key) - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
buildKey(Text, Text, Text) - Method in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
buildKey(Text, Text) - Method in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
buildKey(Text, Text) - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
buildKey(Text, Text, Text) - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
bulkImport(TInfo, AuthInfo, Map<TKeyExtent, Map<String, MapFileInfo>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
bulkImport(TInfo, AuthInfo, Map<TKeyExtent, Map<String, MapFileInfo>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
BulkImportHelper - Class in org.apache.accumulo.core.util
 
BulkImportHelper(Instance, AuthInfo, String) - Constructor for class org.apache.accumulo.core.util.BulkImportHelper
 
BulkImportHelper.AssignmentStats - Class in org.apache.accumulo.core.util
 
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
 
ByteArrayTrie - Class in org.apache.accumulo.core.security
 
ByteArrayTrie(Collection<byte[]>) - Constructor for class org.apache.accumulo.core.security.ByteArrayTrie
 
byteAt(int) - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
byteAt(int) - Method in class org.apache.accumulo.core.data.ByteSequence
 
ByteSequence - Class in org.apache.accumulo.core.data
 
ByteSequence() - Constructor for class org.apache.accumulo.core.data.ByteSequence
 
bytesToLong(byte[]) - Static method in class org.apache.accumulo.core.data.Value
Converts a byte array to a long value
bytesToLong(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
 
bytesToLong(byte[], int) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
 
bytesToLong(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
 
bytesToLongArray(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
 
bytesToString(byte[]) - Static method in class org.apache.accumulo.core.data.Value
Converts a byte array to a string in a consistent manner.

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.Reader - Class in org.apache.accumulo.core.file.blockfile.impl
Class wraps the BCFile reader.
CachableBlockFile.Reader(FileSystem, Path, Configuration, BlockCache, BlockCache) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
CachableBlockFile.Reader(FSDataInputStream, long, Configuration) - 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) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
 
CachableBlockFile.Writer(FSDataOutputStream, String, Configuration) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
 
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
 
CachedConfiguration - Class in org.apache.accumulo.core.util
 
CachedConfiguration() - Constructor for class org.apache.accumulo.core.util.CachedConfiguration
 
CacheEntry - Class in org.apache.accumulo.core.file.blockfile.cache
 
CacheEntry(String, Long) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CacheEntry
 
calculateOverhead(long, long, int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
canCreateTables(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
candidates - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
ceiling(ByteSequence) - Method in class org.apache.accumulo.core.client.impl.Trie
 
ceiling(Text) - Method in class org.apache.accumulo.core.client.impl.Trie
 
changeAuthorizations(TInfo, AuthInfo, String, List<byte[]>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
changeAuthorizations(TInfo, AuthInfo, String, List<byte[]>) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
changePassword(TInfo, AuthInfo, String, byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
changePassword(TInfo, AuthInfo, String, byte[]) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
changeUserAuthorizations(String, Authorizations) - Method in class 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.admin.SecurityOperationsImpl
Set the user's record-level authorizations
changeUserAuthorizations(String, Authorizations) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
changeUserPassword(String, byte[]) - Method in class org.apache.accumulo.core.client.admin.SecurityOperations
Set the user's password
changeUserPassword(String, byte[]) - Method in class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
Set the user's password
changeUserPassword(String, byte[]) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
charAt(int) - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
check(Mutation) - Method in interface org.apache.accumulo.core.constraints.Constraint
Checks a mutation for constrain violations.
check(byte[]) - Method in class org.apache.accumulo.core.security.ByteArrayTrie
 
check() - Method in class org.apache.accumulo.core.security.ByteArrayTrie
 
checkOutputSpecs(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
className - Variable in class org.apache.accumulo.core.data.thrift.IterInfo
 
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() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated. The default cleanup.
clear() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
 
clear() - Method in interface org.apache.accumulo.core.client.IsolatedScanner.RowBuffer
 
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.iterators.HeapIterator
 
clear() - Method in class org.apache.accumulo.core.util.Stat
 
clear() - Method in class org.apache.accumulo.core.zookeeper.ZooCache
 
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 class org.apache.accumulo.core.client.mock.MockScannerBase
 
clearColumns() - Method in interface org.apache.accumulo.core.client.ScannerBase
Clears the columns to be fetched (useful for resetting the scanner for reuse)
clearLocatorCache(String) - Method in class 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.admin.TableOperationsImpl
Clears the tablet locator cache for a specified table
clearLocatorCache(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
clearScanIterators() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Clears scan iterator sprior to returning a scanner to the pool.
clearScanIterators() - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
clearScanIterators() - Method in interface org.apache.accumulo.core.client.ScannerBase
Clears scan iterators prior to returning a scanner to the pool.
clearState() - Method in class org.apache.accumulo.core.security.ByteArrayTrie
 
client - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
CLIENT_RETRIES - Static variable in class org.apache.accumulo.core.Constants
 
CLIENT_SLEEP_BEFORE_RECONNECT - Static variable in class org.apache.accumulo.core.Constants
 
ClientService - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService
 
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, AuthInfo, String, byte[]) - 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.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, AuthInfo, String, List<byte[]>) - 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.changePassword_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.changePassword_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
ClientService.changePassword_args(TInfo, AuthInfo, String, byte[]) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
ClientService.changePassword_args(ClientService.changePassword_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
Performs a deep copy on other.
ClientService.changePassword_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.changePassword_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.changePassword_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
ClientService.changePassword_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
ClientService.changePassword_result(ClientService.changePassword_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
Performs a deep copy on other.
ClientService.changePassword_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.createUser_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.createUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
ClientService.createUser_args(TInfo, AuthInfo, String, byte[], List<byte[]>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
ClientService.createUser_args(ClientService.createUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
Performs a deep copy on other.
ClientService.createUser_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.createUser_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.createUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
ClientService.createUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
ClientService.createUser_result(ClientService.createUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
Performs a deep copy on other.
ClientService.createUser_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.dropUser_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.dropUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
ClientService.dropUser_args(TInfo, AuthInfo, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
ClientService.dropUser_args(ClientService.dropUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
Performs a deep copy on other.
ClientService.dropUser_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.dropUser_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.dropUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
ClientService.dropUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
ClientService.dropUser_result(ClientService.dropUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
Performs a deep copy on other.
ClientService.dropUser_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.finishBulkImport_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.finishBulkImport_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
ClientService.finishBulkImport_args(TInfo, AuthInfo, String, String, boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
ClientService.finishBulkImport_args(ClientService.finishBulkImport_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
Performs a deep copy on other.
ClientService.finishBulkImport_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.finishBulkImport_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.finishBulkImport_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
 
ClientService.finishBulkImport_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
 
ClientService.finishBulkImport_result(ClientService.finishBulkImport_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
Performs a deep copy on other.
ClientService.finishBulkImport_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.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.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, AuthInfo, 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<byte[]>, 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.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, AuthInfo, 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, AuthInfo, 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.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, AuthInfo, 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, AuthInfo, 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.listUsers_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.listUsers_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
ClientService.listUsers_args(TInfo, AuthInfo) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
ClientService.listUsers_args(ClientService.listUsers_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
Performs a deep copy on other.
ClientService.listUsers_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.listUsers_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.listUsers_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
ClientService.listUsers_result(Set<String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
ClientService.listUsers_result(ClientService.listUsers_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
Performs a deep copy on other.
ClientService.listUsers_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(AuthInfo) - 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.prepareBulkImport_args - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.prepareBulkImport_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
ClientService.prepareBulkImport_args(TInfo, AuthInfo, String, String, double) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
ClientService.prepareBulkImport_args(ClientService.prepareBulkImport_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
Performs a deep copy on other.
ClientService.prepareBulkImport_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.prepareBulkImport_result - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.prepareBulkImport_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
ClientService.prepareBulkImport_result(String, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
ClientService.prepareBulkImport_result(ClientService.prepareBulkImport_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
Performs a deep copy on other.
ClientService.prepareBulkImport_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 - Class in org.apache.accumulo.core.client.impl.thrift
 
ClientService.Processor(ClientService.Iface) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor
 
ClientService.Processor.ProcessFunction - Interface in org.apache.accumulo.core.client.impl.thrift
 
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, AuthInfo, 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, AuthInfo, 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.
clip(Range) - Method in class org.apache.accumulo.core.data.Range
 
clip(Range, boolean) - Method in class org.apache.accumulo.core.data.Range
 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
Deprecated. 
clone() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.Key
 
clone() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.TColumn
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.TKey
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.TMutation
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.TRange
Deprecated. 
clone() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
Deprecated. 
clone() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Deprecated. 
clone() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.Compacting
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Deprecated. 
clone() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Deprecated. 
clone() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
Deprecated. 
clone() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
Deprecated. 
clone() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
Deprecated. 
clone() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
Deprecated. 
clone() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
Deprecated. 
clone() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
Deprecated. 
clone() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
Deprecated. 
clone() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
Deprecated. 
clone() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
Deprecated. 
cloneFileAttributes(Path, Path, Progressable) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Clones the attributes (like compression of the input file and creates a corresponding Writer
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 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(ClientService.Iface) - 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.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.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.BloomFilterLayer.Reader
 
close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
close() - Method in class org.apache.accumulo.core.file.FileCFSkippingIterator
 
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
Deprecated.  
close() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Close the map.
close() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Close the map.
close() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Close the file.
close() - Method in interface org.apache.accumulo.core.file.map.MySequenceFile.Sorter.RawKeyValueIterator
Deprecated. closes the iterator so that the underlying streams can be closed
close() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Close the file.
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() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Close the reader.
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Close the scanner.
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Writer
Close the 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.SequenceFileIterator
Deprecated.  
close(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
close(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
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
 
closeDeepCopies() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
closeDeepCopies() - Method in class org.apache.accumulo.core.file.FileCFSkippingIterator
 
closeDeepCopies() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
closeDeepCopies() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
closeDeepCopies() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
closeDeepCopies() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
closeDeepCopies() - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
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) - 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) - 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
 
code - Variable in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
COLF_REGEX - Static variable in class org.apache.accumulo.core.iterators.filter.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.ColumnFamilySkippingIterator
 
collect(Value) - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
 
collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
 
COLQ_REGEX - Static variable in class org.apache.accumulo.core.iterators.filter.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.filter
 
ColumnAgeOffFilter() - Constructor for class org.apache.accumulo.core.iterators.filter.ColumnAgeOffFilter
 
columnFamiliesOptionName - Static variable in class org.apache.accumulo.core.iterators.IntersectingIterator
 
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
 
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.ColumnFamilySkippingIterator
 
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>, Set<ByteSequence>, boolean) - Constructor for class org.apache.accumulo.core.iterators.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.filter
 
ColumnQualifierFilter(HashSet<Column>) - Constructor for class org.apache.accumulo.core.iterators.filter.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
 
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
 
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[], byte[], int) - Constructor for class org.apache.accumulo.core.data.ColumnUpdate
 
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
Empty visibility.
ColumnVisibility(String) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
See ColumnVisibility.ColumnVisibility(byte[])
ColumnVisibility(Text) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
 
ColumnVisibility(byte[]) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Set the column visibility for a Mutation.
ColumnVisibility.Node - Class in org.apache.accumulo.core.security
 
ColumnVisibility.Node(ColumnVisibility.NodeType) - 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
 
ColumnVisibility.NodeComparator(byte[]) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.NodeComparator
 
ColumnVisibility.NodeType - Enum in org.apache.accumulo.core.security
 
colVisibility - Variable in class org.apache.accumulo.core.data.Key
 
colVisibility - Variable in class org.apache.accumulo.core.data.thrift.TKey
 
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.
CompactionStats - Class in org.apache.accumulo.core.tabletserver.thrift
 
CompactionStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
CompactionStats(ActionStats, double, double) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
CompactionStats(CompactionStats) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
Performs a deep copy on other.
CompactionStats._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.
ComparableBytes - Class in org.apache.accumulo.core.data
 
ComparableBytes(byte[]) - Constructor for class org.apache.accumulo.core.data.ComparableBytes
 
COMPARATOR_JCLASS - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.TFile
comparator prefix: java class
COMPARATOR_MEMCMP - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.TFile
comparator: memcmp
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
 
compareColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
 
compareRow(Text) - Method in class org.apache.accumulo.core.data.Key
 
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.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.changePassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
compareTo(ClientService.changePassword_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
compareTo(ClientService.createUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
compareTo(ClientService.createUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
compareTo(ClientService.dropUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
compareTo(ClientService.dropUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
compareTo(ClientService.finishBulkImport_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
compareTo(ClientService.finishBulkImport_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
compareTo(ClientService.listUsers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
compareTo(ClientService.prepareBulkImport_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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(ThriftTableOperationException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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
 
compareTo(Key) - Method in class org.apache.accumulo.core.data.Key
determines the order of keys in the MapFiles we must then just make sure that *'s are not ever stored
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
 
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(TColumn) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
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(Object) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated.  
compareTo(byte[]) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Compare the entry key to another key.
compareTo(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Compare the entry key to another key.
compareTo(RawComparable) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Compare an entry with a RawComparable object.
compareTo(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Compare this version with another version.
compareTo(RelativeKey) - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
compareTo(RFile.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.RFile.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(LoggerStatus) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
compareTo(MasterClientService.createTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
compareTo(MasterClientService.createTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
compareTo(MasterClientService.deleteTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
compareTo(MasterClientService.deleteTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
compareTo(MasterClientService.flushTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
compareTo(MasterClientService.flushTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
compareTo(MasterClientService.offlineTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
compareTo(MasterClientService.onlineTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
compareTo(MasterClientService.onlineTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
compareTo(MasterClientService.renameTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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(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(TabletInfo) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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(AuthInfo) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
compareTo(ThriftSecurityException) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
compareTo(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
compareTo(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
compareTo(CompactionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
compareTo(ConstraintViolationException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
compareTo(LogFile) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
compareTo(MutationLogger.close_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
compareTo(MutationLogger.close_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
compareTo(MutationLogger.create_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
compareTo(MutationLogger.create_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
compareTo(MutationLogger.defineTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
compareTo(MutationLogger.defineTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
compareTo(MutationLogger.getClosedLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
compareTo(MutationLogger.getClosedLogs_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
compareTo(MutationLogger.log_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
compareTo(MutationLogger.log_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
compareTo(MutationLogger.logManyTablets_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
compareTo(MutationLogger.logManyTablets_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
compareTo(MutationLogger.minorCompactionFinished_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
compareTo(MutationLogger.minorCompactionFinished_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
compareTo(MutationLogger.minorCompactionStarted_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
compareTo(MutationLogger.minorCompactionStarted_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
compareTo(MutationLogger.remove_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
compareTo(MutationLogger.startCopy_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
compareTo(MutationLogger.startCopy_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
compareTo(NoSuchLogIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_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.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.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.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
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.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
compareTo(TabletClientService.setUpdateTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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(TabletClientService.useLoggers_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
compareTo(TabletMutations) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
compareTo(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
compareTo(TestService.setTimeOffset_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
compareTo(TestService.setTimeOffset_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
compareTo(TooManyFilesException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
compareTo(ColumnFQ) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
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(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.
compressedValSerializer - Variable in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated.  
COMPRESSION_GZ - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.TFile
compression: gzip
COMPRESSION_LZO - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.TFile
compression: lzo
COMPRESSION_NONE - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.TFile
compression: none
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
config(String...) - Method in class org.apache.accumulo.core.util.shell.Shell
 
ConfigurationObserver - Interface in org.apache.accumulo.core.conf
 
connect(String, int, Watcher) - Static method in class org.apache.accumulo.core.zookeeper.ZooSession
 
Connector - Class in org.apache.accumulo.core.client
Connector facilitates connecting to an Accumulo instance.
Connector() - Constructor for class org.apache.accumulo.core.client.Connector
 
ConnectorImpl - Class in org.apache.accumulo.core.client.impl
 
ConnectorImpl(Instance, String, byte[]) - 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.
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.ColumnFamilySkippingIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.GrepIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.NoLabelIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.RegExIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.SkippingIterator
 
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(byte[]) - Method in class org.apache.accumulo.core.security.Authorizations
 
containsCommand(String) - Method in class org.apache.accumulo.core.util.shell.Token
 
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) - 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
 
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
copyProgress - Variable in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
CORE_PACKAGE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
count - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
count() - Method in class org.apache.accumulo.core.util.shell.EscapeTokenizer
 
CountingIterator - Class in org.apache.accumulo.core.iterators
 
CountingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.CountingIterator
 
create(String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
Create a table with no special configuration
create(String, TimeType) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
create(String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Create a table with no special configuration
create(String, TimeType) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
create(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
create(String, TimeType) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
create() - Method in interface org.apache.accumulo.core.security.VisibilityInterpreter
 
create(ColumnVisibility, Authorizations) - Method in interface org.apache.accumulo.core.security.VisibilityInterpreter
 
create() - Static method in class org.apache.accumulo.core.security.VisibilityInterpreterFactory
 
create(ColumnVisibility, Authorizations) - Static method in class org.apache.accumulo.core.security.VisibilityInterpreterFactory
 
create(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
create(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
create(SocketAddress, long) - Static method in class org.apache.accumulo.core.util.TTimeoutTransport
 
createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
Factory method to create a BatchDeleter connected to Accumulo.
createBatchDeleter(String, Authorizations, int, long, long, int) - 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
 
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
Factory method to create a BatchWriter connected to Accumulo.
createBatchWriter(String, long, long, int) - 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
 
createClient(TServiceClientFactory<T>, TTransport) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
createDataFileReader(FileSystem, Path, Configuration) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Override this method to specialize the type of MySequenceFile.Reader returned.
createFilter(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
createHeap(int) - Method in class org.apache.accumulo.core.iterators.HeapIterator
 
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
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
 
createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
createNewTableTabletDirectories(FileSystem, String, Collection<Text>) - Static method in class org.apache.accumulo.core.util.TabletOperations
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
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
 
createScanner() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get a scanner than can scan the whole TFile.
createScanner(long, long) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get a scanner that covers a portion of TFile based on byte offsets.
createScanner(byte[], byte[]) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get a scanner that covers a portion of TFile based on keys.
createScanner(RawComparable, RawComparable) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get a scanner that covers a specific key range.
createTable(String, String) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
 
createTable(TInfo, AuthInfo, String, List<byte[]>, Map<String, String>, TimeType) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
createTable(TInfo, AuthInfo, String, List<byte[]>, Map<String, String>, TimeType) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
createTabletDirectory(FileSystem, String, Text) - Static method in class org.apache.accumulo.core.util.TabletOperations
 
createTabletDirectory(String, Text) - Static method in class org.apache.accumulo.core.util.TabletOperations
 
createTSocket(String, int) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
createUser(String, byte[], Authorizations) - Method in class org.apache.accumulo.core.client.admin.SecurityOperations
Create a user
createUser(String, byte[], Authorizations) - Method in class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
Create a user
createUser(TInfo, AuthInfo, String, byte[], List<byte[]>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
createUser(TInfo, AuthInfo, String, byte[], List<byte[]>) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
createUser(String, byte[], Authorizations) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
createValueBytes() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated.  
createWriter(FileSystem, Configuration, Path, Class, Class) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of MySequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, MySequenceFile.CompressionType) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of MySequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, MySequenceFile.CompressionType, Progressable) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of MySequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, MySequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of MySequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, MySequenceFile.CompressionType, CompressionCodec, Progressable, MySequenceFile.Metadata) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of MySequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, int, short, long, MySequenceFile.CompressionType, CompressionCodec, Progressable, MySequenceFile.Metadata) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of MySequenceFile Writer.
createWriter(FileSystem, Configuration, Path, Class, Class, MySequenceFile.CompressionType, CompressionCodec, Progressable) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of MySequenceFile Writer.
createWriter(Configuration, FSDataOutputStream, Class, Class, MySequenceFile.CompressionType, CompressionCodec, MySequenceFile.Metadata) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of 'raw' MySequenceFile Writer.
createWriter(Configuration, FSDataOutputStream, Class, Class, MySequenceFile.CompressionType, CompressionCodec) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Construct the preferred type of 'raw' MySequenceFile Writer.
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.changeAuthorizations_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_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.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.splitTablet_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
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
CT - Static variable in class org.apache.accumulo.core.client.impl.Translator
 
current - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
currentLog - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
cve - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
CVST - Static variable in class org.apache.accumulo.core.client.impl.Translator
 

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
 
DATA_FILE_NAME - Static variable in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated. The name of the data file.
DATA_VERSION - Static variable in class org.apache.accumulo.core.Constants
 
DATE_FORMAT - Static variable in class org.apache.accumulo.core.trace.TraceFormatter
 
DebugIterator - Class in org.apache.accumulo.core.iterators
 
DebugIterator(String, SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.DebugIterator
 
decodeBase64FileName(String) - Static method in class org.apache.accumulo.core.util.Encoding
 
decodeBooleans(String) - Static method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
decodeColumnFamilies(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
decodeColumnFamily(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
decodeColumns(String, String) - Static method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
 
decodeColumns(String) - Static method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
decodePrevEndRow(Value) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
decodeRow(Key, Value) - Static method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
decompress(List<TKeyValue>) - Static method in class org.apache.accumulo.core.data.Key
Use this to decompress a list of keys received from thrift.
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.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.changePassword_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args
 
deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.TColumn
 
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.FileCFSkippingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
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
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ColumnFamilySkippingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.CountingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DeletingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DevNull
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FilteringIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.GrepIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.LargeRowFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.MultiIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.NoLabelIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.RegExIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.RowDeletingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ScanCache
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
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.SourceSwitchingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.VersioningIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.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.LoggerStatus
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo
 
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.AuthInfo
 
deepCopy() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_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.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.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.flush_args
 
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.loadTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
DEFAULT_DOC_COLF - Static variable in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
DEFAULT_INDEX_COLF - Static variable in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
DEFAULT_MINOR_COMPACTION_MAX_SLEEP_TIME - Static variable in class org.apache.accumulo.core.Constants
 
DEFAULT_TABLET_LOCATION - 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
 
DefaultFormatter - Class in org.apache.accumulo.core.util.format
 
DefaultFormatter() - Constructor for class org.apache.accumulo.core.util.format.DefaultFormatter
 
DefaultIteratorEnvironment - Class in org.apache.accumulo.core.iterators
 
DefaultIteratorEnvironment() - Constructor for class org.apache.accumulo.core.iterators.DefaultIteratorEnvironment
 
defineTablet(TInfo, long, long, int, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
defineTablet(TInfo, long, long, int, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
delete(String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
Delete a table
delete(String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Delete a table
delete() - Method in interface org.apache.accumulo.core.client.BatchDeleter
 
delete() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchDeleter
 
delete(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
delete(FileSystem, String) - Static method in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated. Deletes the named map file.
DELETE_ROW_VALUE - Static variable in class org.apache.accumulo.core.iterators.RowDeletingIterator
 
deleted - Variable in class org.apache.accumulo.core.data.Key
 
deleted - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
DeleteFilter - Class in org.apache.accumulo.core.iterators.filter
Caller sets up this filter for the rows that they want to match on and then this filter ignores those rows during scans and compactions.
DeleteFilter() - Constructor for class org.apache.accumulo.core.iterators.filter.DeleteFilter
 
deleteLock(String) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
deleteLock(String, String) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
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
 
deleteTable(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
deleteTable(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
DeletingIterator - Class in org.apache.accumulo.core.iterators
 
DeletingIterator(DeletingIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.DeletingIterator
 
DeletingIterator() - Constructor for class org.apache.accumulo.core.iterators.DeletingIterator
 
DeletingIterator(SortedKeyValueIterator<Key, Value>, boolean) - Constructor for class org.apache.accumulo.core.iterators.DeletingIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.filter.AgeOffFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.filter.ColumnAgeOffFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.filter.NoLabelFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.filter.RegExFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.FilteringIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.LargeRowFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.NoLabelIterator
 
describeOptions() - Method in interface org.apache.accumulo.core.iterators.OptionDescriber
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.RegExIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.VersioningIterator
 
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.Shell.AboutCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.AddSplitsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.AuthenticateCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.ClasspathCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.ClearCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.CompactCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.ConfigCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.CreateTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.CreateUserCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.DebugCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteManyCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteScanIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.DropUserCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.EGrepCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.ExecfileCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.ExitCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.FlushCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.FormatterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.GetAuthsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.GetGroupsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.GetSplitsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.GrantCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.GrepCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.HelpCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.HiddenCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.ImportDirectoryCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.InsertCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.ListScansCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.MasterStateCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.OfflineCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.OnlineCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.PasswdCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.RenameTableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.RevokeCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.SelectCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.SelectrowCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.SetAuthsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.SetGroupsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.SetIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.SetScanIterCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.SystemPermissionsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.TableCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.TablePermissionsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.TablesCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.TraceCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.UserCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.UserPermissionsCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.UsersCommand
 
description() - Method in class org.apache.accumulo.core.util.shell.Shell.WhoAmICommand
 
DevNull - Class in org.apache.accumulo.core.iterators
An iterator that is useful testing...
DevNull() - Constructor for class org.apache.accumulo.core.iterators.DevNull
 
dir - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
disableAutoAdjustRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
disableGC - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
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
 
DistributedTrace - Class in org.apache.accumulo.core.trace
 
DistributedTrace() - Constructor for class org.apache.accumulo.core.trace.DistributedTrace
 
docFamilyOptionName - Static variable in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
docSource - Variable in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
doSync() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated. Do the sync checks
dropIndex() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
dropUser(String) - Method in class org.apache.accumulo.core.client.admin.SecurityOperations
Delete a user
dropUser(String) - Method in class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
Delete a user
dropUser(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
dropUser(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
dropUser(String) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
DUMP_TRACE - Static variable in class org.apache.accumulo.core.trace.TraceDump
 
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

elapsed - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
EMPTY - Static variable in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
EMPTY_CF_SET - Static variable in class org.apache.accumulo.core.util.LocalityGroupUtil
 
enable(Instance, String, String) - Static method in class org.apache.accumulo.core.trace.DistributedTrace
 
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
 
encode() - Method in class org.apache.accumulo.core.util.MetadataTable.DataFileValue
 
encodeAsBase64FileName(Text) - Static method in class org.apache.accumulo.core.util.Encoding
 
encodeBooleans(boolean[]) - Static method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
encodeColumnFamilies(Set<Text>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
encodeColumnFamily(ByteSequence) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
encodeColumns() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
 
encodeColumns(Text, Text) - Static method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
 
encodeColumns(Text[]) - Static method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
encodePrevEndRow(Text) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
encodeRow(List<Key>, List<Value>) - Static method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
Encoding - Class in org.apache.accumulo.core.util
 
Encoding() - Constructor for class org.apache.accumulo.core.util.Encoding
 
END_TIME - Static variable in class org.apache.accumulo.core.trace.TraceDump
 
endRow - Variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
entries - Variable in class org.apache.accumulo.core.data.thrift.TMutation
 
entry() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Get an entry to access the key and value.
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.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.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.changePassword_args
 
equals(ClientService.changePassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
equals(ClientService.changePassword_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
equals(ClientService.createUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
equals(ClientService.createUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
equals(ClientService.dropUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
equals(ClientService.dropUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
equals(ClientService.finishBulkImport_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
 
equals(ClientService.finishBulkImport_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args
 
equals(ClientService.listUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
equals(ClientService.listUsers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args
 
equals(ClientService.prepareBulkImport_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
equals(ClientService.prepareBulkImport_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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 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.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.Key
 
equals(Key, PartialKey) - Method in class org.apache.accumulo.core.data.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
 
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.TColumn
 
equals(TColumn) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
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.blockfile.cache.CacheEntry
 
equals(MySequenceFile.Metadata) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Metadata
Deprecated.  
equals(Object) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Metadata
Deprecated.  
equals(Object) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated.  
equals(Object) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Compare whether this and other points to the same key value.
equals(Object) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
 
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.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.LoggerStatus
 
equals(LoggerStatus) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
equals(MasterClientService.createTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
equals(MasterClientService.createTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
equals(MasterClientService.deleteTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
equals(MasterClientService.deleteTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
equals(MasterClientService.flushTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
equals(MasterClientService.flushTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
equals(MasterClientService.offlineTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
equals(MasterClientService.offlineTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
equals(MasterClientService.onlineTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
 
equals(MasterClientService.onlineTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args
 
equals(MasterClientService.renameTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
 
equals(MasterClientService.renameTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo
 
equals(TabletInfo) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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.security.Authorizations
 
equals(Object) - Method in class org.apache.accumulo.core.security.ColumnVisibility
See ColumnVisibility.equals(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.thrift.AuthInfo
 
equals(AuthInfo) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
equals(Object) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
equals(ThriftSecurityException) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
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.ActiveScan
 
equals(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
equals(CompactionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
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.LogFile
 
equals(LogFile) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
equals(MutationLogger.close_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
equals(MutationLogger.close_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
equals(MutationLogger.create_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
equals(MutationLogger.create_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
equals(MutationLogger.defineTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
equals(MutationLogger.defineTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
equals(MutationLogger.getClosedLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
equals(MutationLogger.getClosedLogs_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
equals(MutationLogger.log_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
equals(MutationLogger.log_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
equals(MutationLogger.logManyTablets_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
equals(MutationLogger.logManyTablets_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
equals(MutationLogger.minorCompactionFinished_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
equals(MutationLogger.minorCompactionFinished_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
equals(MutationLogger.minorCompactionStarted_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
equals(MutationLogger.minorCompactionStarted_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
equals(MutationLogger.remove_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
equals(MutationLogger.startCopy_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
equals(MutationLogger.startCopy_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
equals(NoSuchLogIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_args
 
equals(TabletClientService.applyUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_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.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.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.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.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.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.setUpdateTablet_args
 
equals(TabletClientService.setUpdateTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args
 
equals(TabletClientService.useLoggers_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
equals(TabletMutations) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
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.TestService.setTimeOffset_args
 
equals(TestService.setTimeOffset_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
equals(TestService.setTimeOffset_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
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.MetadataTable.DataFileValue
 
equals(Object) - Method in class org.apache.accumulo.core.util.Pair
 
equals(Object) - Method in class org.apache.accumulo.core.util.ServerServices
 
errors - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
errPercent - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
EscapeTokenizer - Class in org.apache.accumulo.core.util.shell
EscapeTokenizer - Supports tokenizing with delimiters while being able to escape the delims.
EscapeTokenizer(String, String) - Constructor for class org.apache.accumulo.core.util.shell.EscapeTokenizer
 
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
 
estimatePercentageLTE(Text, Text, Collection<String>, Text) - Static method in class org.apache.accumulo.core.file.FileUtil
 
estimateSizes(Path, long, List<KeyExtent>, Configuration, FileSystem) - Static method in class org.apache.accumulo.core.file.FileUtil
 
evaluate(ColumnVisibility) - Method in class org.apache.accumulo.core.security.VisibilityEvaluator
 
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
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.AboutCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.AddSplitsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.AuthenticateCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ClasspathCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ClearCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.CompactCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ConfigCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.CreateTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.CreateUserCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.DebugCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteManyCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteScanIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.DropUserCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ExecfileCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ExitCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.FlushCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.FormatterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.GetAuthsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.GetGroupsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.GetSplitsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.GrantCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.GrepCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.HelpCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.HiddenCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ImportDirectoryCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.InsertCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ListScansCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.MasterStateCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.PasswdCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.RenameTableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.RevokeCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.SelectCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.SelectrowCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.SetAuthsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.SetGroupsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.SetIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.SetScanIterCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.SystemPermissionsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.TableCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.TablePermissionsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.TablesCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.TraceCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.UserCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.UserPermissionsCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.UsersCommand
 
execute(String, CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.WhoAmICommand
 
exists(String) - Method in class 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.admin.TableOperationsImpl
A method to check if a table exists in Accumulo.
exists(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
exists(String) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
exists(ZooKeeper, String) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
expireAllObservers() - Method in class org.apache.accumulo.core.conf.TableConfiguration
 
EXTENSION - Static variable in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated.  
EXTENSION - Static variable in class org.apache.accumulo.core.file.rfile.RFile
 
extent - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
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.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
 
failedToAcquireLock(Exception) - Method in interface org.apache.accumulo.core.zookeeper.ZooLock.AsyncLockWatcher
 
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
 
FamilyIntersectingIterator() - Constructor for class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
fetch(ScannerBase, ColumnFQ) - Static 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 class org.apache.accumulo.core.client.mock.MockScannerBase
 
fetchColumn(Text, Text) - Method in interface org.apache.accumulo.core.client.ScannerBase
Limits the scan to only this column, identified by family and qualifier.
fetchColumnFamily(Text) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Limit a scan to the specified column family.
fetchColumnFamily(Text) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
fetchColumnFamily(Text) - Method in interface org.apache.accumulo.core.client.ScannerBase
 
fetchColumns(JobContext, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
fetchColumns(CommandLine, ScannerBase) - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
FILE_TYPE - Static variable in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
FileCFSkippingIterator - Class in org.apache.accumulo.core.file
 
FileCFSkippingIterator(FileSKVIterator) - Constructor for class org.apache.accumulo.core.file.FileCFSkippingIterator
 
FileCFSkippingIterator(SortedKeyValueIterator<Key, Value>, Set<ByteSequence>, boolean) - Constructor for class org.apache.accumulo.core.file.FileCFSkippingIterator
 
filename - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
FileOperations - Class in org.apache.accumulo.core.file
 
FileOperations() - Constructor for class org.apache.accumulo.core.file.FileOperations
 
files - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_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
 
FileUtil - Class in org.apache.accumulo.core.file
 
FileUtil() - Constructor for class org.apache.accumulo.core.file.FileUtil
 
FileUtil.FileInfo - Class in org.apache.accumulo.core.file
 
FileUtil.FileInfo(Key, Key) - Constructor for class org.apache.accumulo.core.file.FileUtil.FileInfo
 
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 - Interface in org.apache.accumulo.core.iterators.filter
 
filter(Text, List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
FilteringIterator - Class in org.apache.accumulo.core.iterators
 
FilteringIterator() - Constructor for class org.apache.accumulo.core.iterators.FilteringIterator
 
FilteringIterator(SortedKeyValueIterator<Key, Value>, List<? extends Filter>) - Constructor for class org.apache.accumulo.core.iterators.FilteringIterator
 
finalKey(WritableComparable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Reads the final key from the file.
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.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.changePassword_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.changePassword_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.createUser_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.createUser_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.dropUser_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.dropUser_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.finishBulkImport_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.finishBulkImport_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.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.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.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.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.listUsers_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.listUsers_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.prepareBulkImport_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.prepareBulkImport_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.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.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.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.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.LoggerStatus._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.createTable_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.createTable_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.deleteTable_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.deleteTable_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.flushTable_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.flushTable_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.offlineTable_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.offlineTable_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.onlineTable_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.onlineTable_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.renameTable_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.renameTable_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.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.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.TabletInfo._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.AuthInfo._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.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.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.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.CompactionStats._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.LogFile._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.MutationLogger.close_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.MutationLogger.close_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.MutationLogger.create_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.MutationLogger.create_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.MutationLogger.defineTablet_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.MutationLogger.defineTablet_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.MutationLogger.getClosedLogs_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.MutationLogger.getClosedLogs_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.MutationLogger.log_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.MutationLogger.log_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.MutationLogger.logManyTablets_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.MutationLogger.logManyTablets_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionStarted_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.MutationLogger.minorCompactionStarted_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.MutationLogger.remove_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.MutationLogger.startCopy_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.MutationLogger.startCopy_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.NoSuchLogIDException._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.applyUpdate_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.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.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.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.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.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.setUpdateTablet_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.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.TabletClientService.useLoggers_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.TabletMutations._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.TestService.setTimeOffset_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.TestService.setTimeOffset_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.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.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.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.changePassword_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.changePassword_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.createUser_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.createUser_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.dropUser_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.dropUser_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.finishBulkImport_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.finishBulkImport_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.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.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.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.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.listUsers_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.listUsers_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.prepareBulkImport_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.prepareBulkImport_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.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.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.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.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.LoggerStatus._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.createTable_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.createTable_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.deleteTable_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.deleteTable_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.flushTable_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.flushTable_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.offlineTable_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.offlineTable_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.onlineTable_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.onlineTable_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.renameTable_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.renameTable_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.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.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.TabletInfo._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.AuthInfo._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.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.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.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.CompactionStats._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.LogFile._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.MutationLogger.close_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.MutationLogger.close_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.MutationLogger.create_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.MutationLogger.create_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.MutationLogger.defineTablet_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.MutationLogger.defineTablet_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.MutationLogger.getClosedLogs_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.MutationLogger.getClosedLogs_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.MutationLogger.log_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.MutationLogger.log_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.MutationLogger.logManyTablets_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.MutationLogger.logManyTablets_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionStarted_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.MutationLogger.minorCompactionStarted_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.MutationLogger.remove_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.MutationLogger.startCopy_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.MutationLogger.startCopy_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.NoSuchLogIDException._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.applyUpdate_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.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.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.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.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.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.setUpdateTablet_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.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.TabletClientService.useLoggers_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.TabletMutations._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.TestService.setTimeOffset_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.TestService.setTimeOffset_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.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.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.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.changePassword_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.changePassword_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.createUser_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.createUser_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.dropUser_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.dropUser_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.finishBulkImport_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.finishBulkImport_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.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.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.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.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.listUsers_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.listUsers_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.prepareBulkImport_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.prepareBulkImport_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.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.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.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.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.LoggerStatus._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.createTable_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.createTable_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.deleteTable_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.deleteTable_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.flushTable_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.flushTable_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.offlineTable_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.offlineTable_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.onlineTable_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.onlineTable_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.renameTable_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.renameTable_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.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.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.TabletInfo._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.AuthInfo._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.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.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.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.CompactionStats._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.LogFile._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.MutationLogger.close_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.MutationLogger.close_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.MutationLogger.create_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.MutationLogger.create_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.MutationLogger.defineTablet_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.MutationLogger.defineTablet_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.MutationLogger.getClosedLogs_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.MutationLogger.getClosedLogs_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.MutationLogger.log_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.MutationLogger.log_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.MutationLogger.logManyTablets_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.MutationLogger.logManyTablets_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionStarted_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.MutationLogger.minorCompactionStarted_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.MutationLogger.remove_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.MutationLogger.startCopy_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.MutationLogger.startCopy_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.NoSuchLogIDException._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.applyUpdate_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.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.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.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.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.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.setUpdateTablet_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.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.TabletClientService.useLoggers_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.TabletMutations._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.TestService.setTimeOffset_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.TestService.setTimeOffset_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.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.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.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.master.thrift.TimeType
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.security.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.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
 
findCommand(Token, int) - Static method in class org.apache.accumulo.core.util.shell.Token
 
findContainingExtent(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
findIterator(IteratorUtil.IteratorScope, String, AccumuloConfiguration, Map<String, String>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
findLastKey(Collection<String>) - Static method in class org.apache.accumulo.core.file.FileUtil
 
findMidPoint(Text, Text, Collection<String>, double) - Static method in class org.apache.accumulo.core.file.FileUtil
 
findMidPoint(Text, Text, Collection<String>, double, boolean) - Static method in class org.apache.accumulo.core.file.FileUtil
 
findOverlapping(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
findOverlapping(KeyExtent, SortedMap<KeyExtent, ? extends Object>) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
finishBulkImport(TInfo, AuthInfo, String, String, boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
finishBulkImport(TInfo, AuthInfo, String, String, boolean) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
finished - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
finishScan() - Method in class org.apache.accumulo.core.iterators.ScanCache
 
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
 
fix(FileSystem, Path, Class<? extends WritableComparable>, Class<? extends Writable>, boolean, Configuration) - Static method in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated. This method attempts to fix a corrupt MapFile by re-creating its index.
flatten() - Method in class org.apache.accumulo.core.security.ColumnVisibility
 
flush(String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
Flush a table
flush(String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Flush a table
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() - 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(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
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(TInfo, AuthInfo, String, Set<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
flush(TInfo, AuthInfo, String, Set<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
flush(Shell, String) - Method in class org.apache.accumulo.core.util.shell.Shell.CompactCommand
 
flush(Shell, String) - Method in class org.apache.accumulo.core.util.shell.Shell.FlushCommand
 
flush(Shell, String) - Method in class org.apache.accumulo.core.util.shell.Shell.OfflineCommand
 
flush(Shell, String) - Method in class org.apache.accumulo.core.util.shell.Shell.OnlineCommand
 
flushTable(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
flushTable(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
followingKey(PartialKey) - Method in class org.apache.accumulo.core.data.Key
Returns a key that will sort immediately after this key.
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
 
formatEntry(Map.Entry<Key, Value>, boolean) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
Formatter - Interface in org.apache.accumulo.core.util.format
 
FormatterFactory - Class in org.apache.accumulo.core.util.format
 
FormatterFactory() - Constructor for class org.apache.accumulo.core.util.format.FormatterFactory
 
fqfn - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
fqfn - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
fromBytes(byte[]) - 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
 
fullScans - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
fullyQualifiedFileName - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 

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.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, AuthInfo) - 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 - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Processor(GCMonitorService.Iface) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor
 
GCMonitorService.Processor.ProcessFunction - Interface in org.apache.accumulo.core.gc.thrift
 
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.
generateInitialTableProperties(List<AggregatorConfiguration>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
get(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
get(Property) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
get(Property) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
get(Property) - Method in class org.apache.accumulo.core.conf.TableConfiguration
 
get(Property) - Method in class org.apache.accumulo.core.conf.ZooConfiguration
 
get() - Method in class org.apache.accumulo.core.data.Value
Get the data from the BytesWritable.
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(WritableComparable, Writable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Return the value for the named key, or null if none exists.
get(Text) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Metadata
Deprecated.  
get(BytesWritable, BytesWritable) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Copy the key and value in one shot into BytesWritables.
get(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
get(String) - Method in class org.apache.accumulo.core.zookeeper.ZooCache
 
get(String, Stat) - Method in class org.apache.accumulo.core.zookeeper.ZooCache
 
getAbbreviatedValue() - Method in interface org.apache.accumulo.core.security.VisibilityInterpreter
 
getActiveScans(String) - Method in class org.apache.accumulo.core.client.admin.InstanceOperations
List the active scans on tablet server.
getActiveScans(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getActiveScans(TInfo, AuthInfo) - 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.ActiveScan
 
getAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAggregator(Key) - Method in class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
 
getAggs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getAggsSize() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getAPIVersion() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Get version of BCFile API.
getAuthorizationFailures() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getAuthorizationFailures() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getAuthorizationFailuresIterator() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getAuthorizationFailuresSize() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
getAuthorizations(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getAuthorizations() - Method in class org.apache.accumulo.core.security.Authorizations
 
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
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_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.client.impl.thrift.ClientService.createUser_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(CommandLine, Shell) - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
getAutoAdjustRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
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
 
getBaseDir() - Static method in class org.apache.accumulo.core.Constants
 
getBatch() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getBatchFromServer(AuthInfo, Text, KeyExtent, String, SortedMap<Key, Value>, SortedSet<Column>, boolean, int, Authorizations, boolean, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.client.impl.ThriftScanner
 
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
 
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
 
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.blockfile.impl.CachableBlockFile.Reader
 
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.
getBoolean(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
getByDepth(int) - Static method in enum org.apache.accumulo.core.data.PartialKey
 
getBytes() - Method in class org.apache.accumulo.core.data.ComparableBytes
 
getBytes(Writable) - Static method in class org.apache.accumulo.core.data.Value
 
getBytes(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
getCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getCaseSensitive() - Method in class org.apache.accumulo.core.util.shell.Token
 
getChildren() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getChildren(String) - Method in class org.apache.accumulo.core.zookeeper.ZooCache
 
getClassName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
getClassName() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
 
getClient() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
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.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.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.MutationLogger.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client.Factory
 
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(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client.Factory
 
getClient(TServiceClientFactory<T>, InetSocketAddress, 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, Property, Property, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
getClosedLogs(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
getClosedLogs(TInfo, AuthInfo) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
getClosest(WritableComparable, Writable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Finds the record that is the closest match to the specified key.
getClosest(WritableComparable, Writable, boolean) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Finds the record that is the closest match to the specified key.
getClosest(WritableComparable, Writable, boolean, WritableComparable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
getCode() - Method in exception org.apache.accumulo.core.security.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.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
 
getColumnFamily() - Method in class org.apache.accumulo.core.data.Key
 
getColumnFamily() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getColumnFamily() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
 
getColumnFamily() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
getColumnFamilyData() - Method in class org.apache.accumulo.core.data.Key
 
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
 
getColumnQualifier() - Method in class org.apache.accumulo.core.data.Key
 
getColumnQualifier() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getColumnQualifier() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
 
getColumnQualifier() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
getColumnQualifierData() - Method in class org.apache.accumulo.core.data.Key
 
getColumns() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
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
 
getColumnVisibility(Text) - Method in class org.apache.accumulo.core.data.Key
 
getColumnVisibility() - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getColumnVisibilityData() - Method in class org.apache.accumulo.core.data.Key
 
getColVisibility() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getCommandByName(String) - Method in class org.apache.accumulo.core.util.shell.Shell.CommandFactory
 
getCommandNames() - Method in class org.apache.accumulo.core.util.shell.Token
 
getCommandNames(String) - Method in class org.apache.accumulo.core.util.shell.Token
 
getCommandTable() - Method in class org.apache.accumulo.core.util.shell.Shell.CommandFactory
 
getComparator() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get an instance of the RawComparator that is constructed based on the string comparator representation.
getComparatorName() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get the string representation of the comparator.
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.
getCompressionCodec() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns the compression codec of data in this file.
getCompressionCodec() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Returns the compression codec of data in this file.
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.
getCompressionType(Configuration) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Use SequenceFileOutputFormat.getOutputCompressionType(org.apache.hadoop.mapred.JobConf) to get MySequenceFile.CompressionType for job-outputs.
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 class org.apache.accumulo.core.iterators.DefaultIteratorEnvironment
 
getConfig() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
getConfiguration() - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
getConfiguration() - Method in interface org.apache.accumulo.core.client.Instance
get the AccumuloConfiguration to use when interacting with this instance
getConfiguration() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getConfiguration() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getConnection(Instance) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
getConnection(Instance, boolean) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
 
getConnection(Instance) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
 
getConnector(String, byte[]) - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
getConnector(String, CharSequence) - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
getConnector(String, byte[]) - Method in interface org.apache.accumulo.core.client.Instance
 
getConnector(String, CharSequence) - Method in interface org.apache.accumulo.core.client.Instance
 
getConnector(String, byte[]) - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getConnector(String, CharSequence) - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getConnector(String, CharSequence) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getConnector(String, byte[]) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
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
 
getCopyProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getCount(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getCount() - Method in class org.apache.accumulo.core.iterators.CountingIterator
 
getCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
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.changeAuthorizations_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.flush_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.splitTablet_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
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
getCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
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(Writable) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Get the 'value' corresponding to the last read 'key'.
getCurrentValue(Object) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Get the 'value' corresponding to the last read 'key'.
getCve() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getData(ZooKeeper, String, Stat) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
getData(String, Stat) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
getDataBlock(int) - 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(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Stream access to a Data Block.
getDataVersionLocation() - Static method in class org.apache.accumulo.core.Constants
 
getDeepCopyDataSource(IteratorEnvironment) - Method in interface org.apache.accumulo.core.iterators.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
 
getDefaultTableName(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getDefaultValue() - Method in enum org.apache.accumulo.core.conf.Property
 
getDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getDepth() - Method in enum org.apache.accumulo.core.data.PartialKey
 
getDescription() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getDescription() - Method in enum org.apache.accumulo.core.conf.Property
 
getDir() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
getDocID(Key) - Method in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
getDocID(Key) - Method in class org.apache.accumulo.core.iterators.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
 
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
 
getEntries() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getEntries(Instance, AuthInfo, String, boolean, Map<KeyExtent, String>, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.util.MetadataTable
 
getEntryComparator() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get a Comparator object to compare Entries.
getEntryCount() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get the number of key-value pair entries in TFile.
getErrorCode() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getErrorServers() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getErrPercent() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
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
getExpression() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Accessor for the underlying byte string.
getExtent() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
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.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
 
getFactor() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Get the number of streams to merge at once.
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
 
getFetchedColumns() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
getFetchedColumns(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
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.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.changePassword_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.ThriftTableOperationException._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.TColumn._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.LoggerStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo._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.AuthInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.security.thrift.ThriftSecurityException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.LogFile._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException._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.applyUpdate_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.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.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.flush_args._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.loadTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletMutations._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
 
getFieldValue(ClientService.authenticateUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
getFieldValue(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
getFieldValue(ClientService.changeAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getFieldValue(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
getFieldValue(ClientService.changePassword_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
getFieldValue(ClientService.changePassword_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
getFieldValue(ClientService.createUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
getFieldValue(ClientService.createUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
getFieldValue(ClientService.dropUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
getFieldValue(ClientService.dropUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
getFieldValue(ClientService.finishBulkImport_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
getFieldValue(ClientService.finishBulkImport_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
 
getFieldValue(ClientService.getInstanceId_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
getFieldValue(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
getFieldValue(ClientService.getRootTabletLocation_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
getFieldValue(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
getFieldValue(ClientService.getUserAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
getFieldValue(ClientService.grantSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
getFieldValue(ClientService.hasSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
getFieldValue(ClientService.listUsers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
getFieldValue(ClientService.listUsers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
getFieldValue(ClientService.ping_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
getFieldValue(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
getFieldValue(ClientService.prepareBulkImport_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
getFieldValue(ClientService.prepareBulkImport_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
getFieldValue(ClientService.revokeSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
getFieldValue(ThriftTableOperationException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getFieldValue(int) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
getFieldValue(InitialMultiScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
getFieldValue(InitialScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
getFieldValue(IterInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
getFieldValue(MapFileInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
getFieldValue(MultiScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
getFieldValue(ScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
getFieldValue(TColumn._Fields) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
getFieldValue(TConstraintViolationSummary._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
getFieldValue(TKey._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
getFieldValue(TKeyExtent._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
getFieldValue(TKeyValue._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
getFieldValue(TMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
getFieldValue(TRange._Fields) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
getFieldValue(UpdateErrors._Fields) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getFieldValue(int) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
getFieldValue(GcCycleStats._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getFieldValue(Compacting._Fields) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getFieldValue(LoggerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
getFieldValue(MasterClientService.createTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getFieldValue(MasterClientService.createTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
getFieldValue(MasterClientService.deleteTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
getFieldValue(MasterClientService.deleteTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
getFieldValue(MasterClientService.flushTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
getFieldValue(MasterClientService.flushTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
getFieldValue(MasterClientService.getMasterStats_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
getFieldValue(int) - 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(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
getFieldValue(MasterClientService.offlineTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
getFieldValue(MasterClientService.offlineTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
getFieldValue(MasterClientService.onlineTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
getFieldValue(MasterClientService.onlineTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
 
getFieldValue(MasterClientService.removeSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
getFieldValue(MasterClientService.renameTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
getFieldValue(MasterClientService.renameTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
 
getFieldValue(MasterClientService.reportSplitExtent_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
getFieldValue(MasterClientService.setSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
getFieldValue(MasterMonitorInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getFieldValue(RecoveryException._Fields) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
getFieldValue(int) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
getFieldValue(RecoveryStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getFieldValue(TableInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getFieldValue(TabletInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getFieldValue(TabletServerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getFieldValue(TabletSplit._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
getFieldValue(int) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
getFieldValue(AuthInfo._Fields) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
getFieldValue(int) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
getFieldValue(ThriftSecurityException._Fields) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
getFieldValue(int) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
getFieldValue(ActionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getFieldValue(ActiveScan._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getFieldValue(CompactionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
getFieldValue(ConstraintViolationException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
getFieldValue(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
getFieldValue(LogFile._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
getFieldValue(MutationLogger.close_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
getFieldValue(MutationLogger.close_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
getFieldValue(MutationLogger.create_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
getFieldValue(MutationLogger.create_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
getFieldValue(MutationLogger.defineTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
getFieldValue(MutationLogger.defineTablet_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
getFieldValue(MutationLogger.getClosedLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
getFieldValue(MutationLogger.getClosedLogs_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
getFieldValue(MutationLogger.log_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
getFieldValue(MutationLogger.log_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
getFieldValue(MutationLogger.logManyTablets_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
getFieldValue(MutationLogger.logManyTablets_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
getFieldValue(MutationLogger.minorCompactionFinished_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
getFieldValue(MutationLogger.minorCompactionFinished_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
getFieldValue(MutationLogger.minorCompactionStarted_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
getFieldValue(MutationLogger.minorCompactionStarted_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
getFieldValue(MutationLogger.remove_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
getFieldValue(MutationLogger.startCopy_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
getFieldValue(MutationLogger.startCopy_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
getFieldValue(NoSuchLogIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
getFieldValue(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
getFieldValue(NoSuchScanIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
getFieldValue(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
getFieldValue(NotServingTabletException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
getFieldValue(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
getFieldValue(TabletClientService.applyUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
getFieldValue(TabletClientService.bulkImport_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getFieldValue(int) - 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(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getFieldValue(TabletClientService.closeMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
getFieldValue(TabletClientService.continueMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
getFieldValue(TabletClientService.flush_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getFieldValue(TabletClientService.getActiveScans_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
getFieldValue(TabletClientService.loadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getFieldValue(TabletClientService.setUpdateTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
getFieldValue(TabletClientService.splitTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getFieldValue(int) - 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(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
getFieldValue(TabletClientService.startMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
getFieldValue(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - 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(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getFieldValue(TabletClientService.useLoggers_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
getFieldValue(TabletMutations._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
getFieldValue(TabletStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getFieldValue(TestService.setTimeOffset_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
getFieldValue(TestService.setTimeOffset_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
getFieldValue(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
getFieldValue(TooManyFilesException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
getFieldValue(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getFilesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_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
Deprecated.  
getFileSize(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
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 class org.apache.accumulo.core.file.FileCFSkippingIterator
 
getFirstKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getFirstKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
getFirstKey() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
getFirstKey() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get the first key in the TFile.
getFirstKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getFirstKey() - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
getFirstRow() - Method in class org.apache.accumulo.core.file.FileUtil.FileInfo
 
getFixedProperties() - Static method in enum org.apache.accumulo.core.conf.Property
 
getFormatter(Class<? extends Formatter>, Iterable<Map.Entry<Key, Value>>, boolean) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
 
getFqfn() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
getFqfn() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
getFraction(Property) - 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.
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
 
getFullValue() - Method in interface org.apache.accumulo.core.security.VisibilityInterpreter
 
getFullyQualifiedFileName() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
getGoalState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getHashInfo() - Method in class org.apache.accumulo.core.file.blockfile.cache.CacheEntry
 
getHistoricalStats(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getHistoricalStats(TInfo, AuthInfo) - 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
 
getHost() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getId() - Method in enum org.apache.accumulo.core.security.SystemPermission
 
getId() - Method in enum org.apache.accumulo.core.security.TablePermission
 
getId() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
getId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
getId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
getId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
getId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
getId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
getId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
getID() - Method in class org.apache.accumulo.core.util.shell.Token
 
getIdleTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getIdToNameMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getIndex() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getIndexInterval() - Static method in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated.  
getIndexInterval() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. The number of entries that are added before an index entry is added.
getIndexPosition(WritableComparable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
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
 
getInputProtocol() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getInputProtocol() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
getInputProtocol() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
getInputProtocol() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
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.HdfsZooInstance
 
getInstance(Instance, AuthInfo, Text) - Static method in class org.apache.accumulo.core.client.impl.TabletLocator
 
getInstance() - Static method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getInstance() - Method in class org.apache.accumulo.core.client.mock.MockConnector
 
getInstance() - Static method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
getInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.conf.ZooConfiguration
 
getInstance(Instance, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.conf.ZooConfiguration
 
getInstance() - Static method in class org.apache.accumulo.core.file.FileOperations
 
getInstance(CommandLine) - Static method in class org.apache.accumulo.core.trace.TraceDump
 
getInstance() - Static method in class org.apache.accumulo.core.util.CachedConfiguration
 
getInstance(String, int) - Static method in class org.apache.accumulo.core.zookeeper.ZooCache
 
getInstanceID() - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
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
Get 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.AuthInfo
 
getInstanceIdLocation() - Static method in class org.apache.accumulo.core.Constants
 
getInstanceName() - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
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.mock.MockInstance
 
getInstanceName() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getIteratorOptions(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getIterators(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getIteratorScope() - Method in class org.apache.accumulo.core.iterators.DefaultIteratorEnvironment
 
getIteratorScope() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
getIterName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
getKey() - Method in enum org.apache.accumulo.core.conf.Property
 
getKey() - Method in class org.apache.accumulo.core.data.KeyValue
 
getKey() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
getKey() - Method in interface org.apache.accumulo.core.file.map.MySequenceFile.Sorter.RawKeyValueIterator
Deprecated. Gets the current raw key
getKey() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated. Returns the stored rawKey
getKey(BytesWritable) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Copy the key into BytesWritable.
getKey(byte[]) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Copy the key into user supplied buffer.
getKey(byte[], int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Copy the key into user supplied buffer.
getKey() - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
getKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.IndexEntry
 
getKeyClass() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Returns the class of keys in this file.
getKeyClass() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns the class of keys in this file.
getKeyClass() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Returns the class of keys in this file.
getKeyClassName() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns the name of the key class.
getKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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
Empty start or end rows tell the method there are no start or end rows, and to use all the keyextents that are before the end row if no start row etc.
getKeyLength() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Get the length of the key.
getKeyNear(long) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get a sample key that is within a block whose starting offset is greater than or equal to the specified offset.
getKeyStream() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Streaming access to the key.
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
 
getLastKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getLastKey() - Method in class org.apache.accumulo.core.file.FileCFSkippingIterator
 
getLastKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getLastKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
getLastKey() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
getLastKey() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Get the last key in the TFile.
getLastKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getLastKey() - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
getLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getLastRow() - Method in class org.apache.accumulo.core.file.FileUtil.FileInfo
 
getLeft() - Method in class org.apache.accumulo.core.util.BinaryTree
 
getLength() - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat.RangeInputSplit
This is merely a ballpark try, please don't use it for accurate numbers.
getLength() - Method in class org.apache.accumulo.core.data.ComparableBytes
 
getLength() - Method in class org.apache.accumulo.core.data.Key
 
getLength() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Returns the current length of the output file.
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.
getLocalityGroups(String) - Method in class 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.admin.TableOperationsImpl
Gets the locality groups currently set for a table.
getLocalityGroups(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
getLocalityGroups(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
getLocations() - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat.RangeInputSplit
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_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
 
getLockData(ZooKeeper, String) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
getLockData(ZooCache, String) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
getLockData(String) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
getLockFile() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
getLockID() - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
getLockName() - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
getLockPath() - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
getLogger() - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
getLoggers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getLoggers() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLoggers() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
getLoggersIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getLoggersIterator() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLoggersIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
getLoggersSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getLoggersSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLoggersSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
getLogLevel(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getLogLevel(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
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.
getMajor() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getMajor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getMajorCount() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMajorElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMajorFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMajorNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMajorQueueSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMajorQueueTime() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMajorSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMajorVersion() - Method in class org.apache.accumulo.core.util.Version
 
getMapProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getMasterLocations() - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
getMasterLocations() - Method in interface org.apache.accumulo.core.client.Instance
Get 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, AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
getMasterStats(TInfo, AuthInfo) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
getMax() - Method in class org.apache.accumulo.core.util.Stat
 
getMaxLatency(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getMaxMutationBufferSize(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getMaxPriority(IteratorUtil.IteratorScope, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
Get the maximum size of this cache.
getMaxVersions(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getMaxWriteThreads(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getMemory() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Get the total amount of buffer memory, in bytes.
getMemoryInBytes(Property) - 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(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(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Stream access to a Meta Block.
getMetaBlock(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Stream access to a meta block.``
getMetadata() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Metadata
Deprecated.  
getMetadata() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns the metadata object of the file
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.util.MetadataTable
 
getMetadataTableDir() - Static method in class org.apache.accumulo.core.Constants
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.FileCFSkippingIterator
 
getMetaStore(String) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
getMetaStore(String) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
getMetaStore(String) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getMetaStore(String) - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
getMillis() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
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.
getMinor() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getMinor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getMinorCount() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMinorElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMinorFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMinorNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMinorQueueSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMinorQueueTime() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getMinorSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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.tabletserver.thrift.MutationLogger.log_args
 
getMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
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.MutationLogger.logManyTablets_args
 
getMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
getMutationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
getMutationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
getMutationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
getMutationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
getName() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
getName() - Method in class org.apache.accumulo.core.file.blockfile.cache.CacheEntry
 
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.LogFile
 
getName() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
getName() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
getName() - Method in class org.apache.accumulo.core.util.shell.Shell.HiddenCommand
 
getName() - Method in class org.apache.accumulo.core.util.shell.Shell.QuestionCommand
 
getNameToIdMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
 
getNewDataSource() - Method in interface org.apache.accumulo.core.iterators.SourceSwitchingIterator.DataSource
 
getNewFileExtension(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.FileOperations
 
getNewTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
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
 
getNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
getNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
getNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
getNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
getNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
getNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
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.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.RFile.IndexEntry
 
getNumEntries() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getNumEntries() - Method in class org.apache.accumulo.core.util.MetadataTable.DataFileValue
 
getObject(Key) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
getOldTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
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
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.AboutCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.AddSplitsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.CompactCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.ConfigCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.CreateTableCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.CreateUserCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteManyCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteScanIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.ExecfileCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.FlushCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.FormatterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.GetAuthsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.GetGroupsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.GetSplitsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.GrantCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.GrepCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.HelpCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.ImportDirectoryCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.InsertCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.ListScansCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.PasswdCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.RevokeCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.SelectCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.SelectrowCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.SetAuthsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.SetGroupsCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.SetIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.SetScanIterCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.TablesCommand
 
getOptions() - Method in class org.apache.accumulo.core.util.shell.Shell.UserPermissionsCommand
 
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
 
getOutputProtocol() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getOutputProtocol() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
getOutputProtocol() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
getOutputProtocol() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
getPackage() - Method in class org.apache.accumulo.core.util.Version
 
getParent() - Method in class org.apache.accumulo.core.util.BinaryTree
 
getParseTree() - Method in class org.apache.accumulo.core.security.ColumnVisibility
 
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.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.authenticateUser_args
 
getPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
getPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
getPassword(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
WARNING: The password is stored in the Configuration and shared with all MapReduce tasks; It is BASE64 encoded to provide a charset safe conversion to a string, and is not intended to be secure.
getPassword(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
WARNING: The password is stored in the Configuration and shared with all MapReduce tasks; It is BASE64 encoded to provide a charset safe conversion to a string, and is not intended to be secure.
getPassword() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
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.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.SystemPermission
 
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.TablePermission
 
getPort(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getPosition() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Return the current byte position in the input file.
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
 
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
 
getPrintableTableIdFromName(Map<String, String>, 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.data.thrift.IterInfo
 
getPriority() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
getProgress(ByteSequence, ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat.RangeInputSplit
 
getProgress(Key) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat.RangeInputSplit
 
getProgress() - Method in interface org.apache.accumulo.core.file.map.MySequenceFile.Sorter.RawKeyValueIterator
Deprecated. Gets the Progress object; this has a float (0.0 - 1.0) indicating the bytes processed by the iterator so far
getProperties(String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
Gets properties of a table
getProperties(String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Gets properties of a table
getProperties(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
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.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.conf.Property
 
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
 
getQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
getQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
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.mock.MockScanner
 
getRange() - Method in interface org.apache.accumulo.core.client.Scanner
 
getRange() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
getRange(CommandLine) - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
getRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
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.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getRecovery() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getRecoveryDir() - Static method in class org.apache.accumulo.core.Constants
 
getRecoveryIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getRecoverySize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getRecs() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getRecsInMemory() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getReduceProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getRegex(JobContext, AccumuloInputFormat.RegexType) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getReleaseVersion() - Method in class org.apache.accumulo.core.util.Version
 
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.data.thrift.InitialMultiScan
 
getResult() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
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
 
getRootTabletDir() - Static method in class org.apache.accumulo.core.Constants
 
getRootTabletLocation() - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
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
Get 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
 
getRow() - Method in class org.apache.accumulo.core.data.Key
 
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
 
getRowData() - Method in class org.apache.accumulo.core.data.Key
 
getRunning() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getRuntime() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getScanid() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
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.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
 
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.changeAuthorizations_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_result
 
getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
getSecond() - Method in class org.apache.accumulo.core.util.Pair
 
getSecs(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
getSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
getSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
getSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
getSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
getSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
getSerialVersion() - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
getServer() - Method in exception org.apache.accumulo.core.client.impl.AccumuloServerException
 
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
 
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
 
getSession(String, int) - Static method in class org.apache.accumulo.core.zookeeper.ZooSession
 
getSession() - Static method in class org.apache.accumulo.core.zookeeper.ZooSession
 
getSession(Watcher) - Static method in class org.apache.accumulo.core.zookeeper.ZooSession
 
getSessionId(ZooCache, String) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
getSessionId() - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
getSimulationMode(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getSiteConfiguration() - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getSize() - Method in class org.apache.accumulo.core.data.Key
 
getSize() - Method in class org.apache.accumulo.core.data.Value
 
getSize() - Method in interface org.apache.accumulo.core.file.map.MySequenceFile.ValueBytes
Deprecated. Size of stored data.
getSize() - Method in class org.apache.accumulo.core.util.MetadataTable.DataFileValue
 
getSource() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getSplit() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
getSplit() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getSplitElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getSplitFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getSplitNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getSplitPoints() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getSplitPointsIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getSplitPointsSize() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getSplits(String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
getSplits(String, int) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
getSplits(String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
getSplits(String, int) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
getSplits(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
read the metadata table to get tablets of interest these each become a split
getSplits(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
getSplits(String, int) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
getSplitSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getSsiList() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
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.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.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.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.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
 
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 class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Get the starting position of the block in the file.
getState() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
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.tabletserver.thrift.CompactionStats
 
getStatus(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
getStatus(TInfo, AuthInfo) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.Iface
 
getStatus() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
getStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getStatus(String) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
getStatus(ZooKeeper, String) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
getStatusMajor() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getStatusMinor() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
getStatusSplit() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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.getInstanceId_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.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.listUsers_result
 
getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
getSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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.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.getUserAuthorizations_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_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.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.getUserAuthorizations_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_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.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
 
getSupportedCompressionAlgorithms() - Static method in class org.apache.accumulo.core.file.rfile.bcfile.TFile
Get names of supported compression algorithms.
getSysPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
getSystemConfiguration() - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getSystemConfiguration(Instance) - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getTable() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
getTableConfiguration(String, String) - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getTableConfiguration(String, String, Instance) - 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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.getTabletStats_args
 
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(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.finishBulkImport_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.prepareBulkImport_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(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getTableName() - Method in exception org.apache.accumulo.core.client.TableNotFoundException
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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
 
getTables() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getTablesDir() - Static method in class org.apache.accumulo.core.Constants
 
getTablesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getTablesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getTablet() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
getTablet() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
getTabletAndPrevTabletKeyValues(Instance, SortedMap<Key, Value>, KeyExtent, List<ColumnFQ>, AuthInfo) - Static method in class org.apache.accumulo.core.util.MetadataTable
 
getTabletEntries(Instance, KeyExtent, List<ColumnFQ>, AuthInfo) - Static method in class org.apache.accumulo.core.util.MetadataTable
 
getTabletEntries(SortedMap<Key, Value>, List<ColumnFQ>) - Static method in class org.apache.accumulo.core.util.MetadataTable
 
getTabletID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
getTabletLocator(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getTabletServer() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
getTabletServers() - Method in class org.apache.accumulo.core.client.admin.InstanceOperations
List the currently active tablet servers participating in the accumulo instance
getTabletServerStatus(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getTabletServerStatus(TInfo, AuthInfo) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getTabletStats(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getTabletStats(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getTblPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
getTerm(Key) - Method in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
getTerm(Key) - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
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.IntersectingIterator.TermSource
 
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.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.changePassword_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.ThriftTableOperationException._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.TColumn._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.LoggerStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo._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.AuthInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.security.thrift.ThriftSecurityException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.LogFile._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException._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.applyUpdate_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.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.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.flush_args._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.loadTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletMutations._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
 
getTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
getTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
getTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
getTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
getTimeInMillis(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getTimeOut() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
 
getTimeOut() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getTimeOut() - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
getTimeOut() - Method in interface org.apache.accumulo.core.client.Scanner
 
getTimestamp() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
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.authenticateUser_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.changePassword_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_args
 
getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.close_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_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.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.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.flush_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.loadTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_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
 
getTokens() - Method in class org.apache.accumulo.core.util.shell.QuotedStringTokenizer
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.hasTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_result
 
getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
getTopKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getTopKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
getTopKey() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
getTopKey() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
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.HeapIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.LargeRowFilter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.RowDeletingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.ScanCache
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
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.SourceSwitchingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getTopValue() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
getTopValue() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
getTopValue() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
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.HeapIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.LargeRowFilter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.RowDeletingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.ScanCache
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
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.SourceSwitchingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getTransport(String, int) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getTransport(InetSocketAddress, long) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getTransport(String, int, long) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getTransportWithDefaultTimeout(InetSocketAddress, AccumuloConfiguration) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getTransportWithDefaultTimeout(String, int, AccumuloConfiguration) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
getTServerClient(String, AccumuloConfiguration) - 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
 
getTserverSession() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
getTt() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
getType() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
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.ActiveScan
 
getUnassignedTablets() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
getUnknownExceptions() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
getUpdates() - Method in class org.apache.accumulo.core.data.Mutation
 
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.thrift.ClientService.authenticateUser_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
getUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
getUser() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
getUser() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
getUser() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getUserAuthorizations(String) - Method in class org.apache.accumulo.core.client.admin.SecurityOperations
Retrieves the user's authorizations for scanning
getUserAuthorizations(String) - Method in class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
Retrieves the user's authorizations for scanning
getUserAuthorizations(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
getUserAuthorizations(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
getUserAuthorizations(String) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
getUsername(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
getUsername(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
getUUID() - Method in class org.apache.accumulo.core.data.KeyExtent
 
getValidExtensions() - Static method in class org.apache.accumulo.core.file.FileOperations
 
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.KeyValue
 
getValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
getValue() - Method in interface org.apache.accumulo.core.file.map.MySequenceFile.Sorter.RawKeyValueIterator
Deprecated. Gets the current raw value
getValue(BytesWritable) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Copy the value into BytesWritable.
getValue(byte[]) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Copy value into user-supplied buffer.
getValue(byte[], int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Copy value into user-supplied buffer.
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 enum org.apache.accumulo.core.master.thrift.TimeType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.security.thrift.SecurityErrorCode
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.
getValueClass() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Returns the class of values in this file.
getValueClass() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns the class of values in this file.
getValueClass() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Returns the class of values in this file.
getValueClassName() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns the name of the value class.
getValueLength() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Get the length of the value.
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
 
getValueStream() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Stream access to value.
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() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getViolationDescription() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
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
 
getWhy() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
getWritable(byte[], Writable) - Static method in class org.apache.accumulo.core.data.Value
Set bytes into the passed Writable by calling its Writable.readFields(java.io.DataInput).
getZooKeepers() - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
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
 
getZooKeepers() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getZooKeepers() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
getZooKeepersSessionTimeOut() - Method in interface org.apache.accumulo.core.client.Instance
 
getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
goalState - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
grantSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.admin.SecurityOperations
Grant a user a system permission
grantSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
Grant a user a system permission
grantSystemPermission(TInfo, AuthInfo, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
grantSystemPermission(TInfo, AuthInfo, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
grantSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
grantTablePermission(String, String, TablePermission) - Method in class 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.admin.SecurityOperationsImpl
Grant a user a specific permission for a specific table
grantTablePermission(TInfo, AuthInfo, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
grantTablePermission(TInfo, AuthInfo, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
grantTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
GrepIterator - Class in org.apache.accumulo.core.iterators
 
GrepIterator() - Constructor for class org.apache.accumulo.core.iterators.GrepIterator
 

H

halt(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
halt(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
hasColumns(Key) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
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.impl.TabletLocator.TabletLocation
 
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.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.changePassword_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args
 
hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.Key
 
hashCode() - Method in class org.apache.accumulo.core.data.KeyExtent
 
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.TColumn
 
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.blockfile.cache.CacheEntry
 
hashCode() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Metadata
Deprecated.  
hashCode() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated.  
hashCode() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
 
hashCode() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
 
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.master.thrift.Compacting
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args
 
hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo
 
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.security.Authorizations
 
hashCode() - Method in class org.apache.accumulo.core.security.ColumnVisibility
 
hashCode() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
hashCode() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_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.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.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.flush_args
 
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.loadTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
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.MetadataTable.DataFileValue
 
hashCode() - Method in class org.apache.accumulo.core.util.Pair
 
hashCode() - Method in class org.apache.accumulo.core.util.ServerServices
 
hashType - Variable in class org.apache.accumulo.core.bloomfilter.Filter
Type of hashing function to use.
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.trace.TraceFormatter
 
hasNext() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
hasNext() - Method in class org.apache.accumulo.core.util.format.DeleterFormatter
 
hasSystemPermission(String, SystemPermission) - Method in class 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.admin.SecurityOperationsImpl
Verify the user has a particular system permission
hasSystemPermission(TInfo, AuthInfo, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
hasSystemPermission(TInfo, AuthInfo, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
hasSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
hasTablePermission(String, String, TablePermission) - Method in class 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.admin.SecurityOperationsImpl
Verify the user has a particular table permission
hasTablePermission(TInfo, AuthInfo, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
hasTablePermission(TInfo, AuthInfo, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
hasTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
hasTimestamp() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
hasTop() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
hasTop() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
hasTop() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
hasTop() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
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.HeapIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.LargeRowFilter
 
hasTop() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.RowDeletingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.ScanCache
 
hasTop() - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
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.SourceSwitchingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.VersioningIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
hasTop() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
HdfsZooInstance - Class in org.apache.accumulo.core.client.impl
An implementation of Instance that looks in HDFS and ZooKeeper to find the master and root tablet location.
HdfsZooInstance() - Constructor for class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
HdfsZooInstance.AccumuloNotInitializedException - Exception in org.apache.accumulo.core.client.impl
 
HdfsZooInstance.AccumuloNotInitializedException(String) - Constructor for exception org.apache.accumulo.core.client.impl.HdfsZooInstance.AccumuloNotInitializedException
 
HeapIterator - Class in org.apache.accumulo.core.iterators
 
HeapIterator() - Constructor for class org.apache.accumulo.core.iterators.HeapIterator
 
HeapIterator(int) - Constructor for class org.apache.accumulo.core.iterators.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
 
hit() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
holdTime - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
host - Variable in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 

I

id - Variable in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
id - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
id - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
id - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
id - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
id - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
id - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
idleTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
importDirectory(String, String, String, int, int, boolean) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
importDirectory(String, String, String, int, int, boolean) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
importDirectory(String, String, String, int, int, boolean) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
importDirectory(Path, Path, int, int, boolean) - Method in class org.apache.accumulo.core.util.BulkImportHelper
 
inclusive - Variable in class org.apache.accumulo.core.iterators.ColumnFamilySkippingIterator
 
inclusive - Variable in class org.apache.accumulo.core.iterators.IntersectingIterator
 
INDEX_FILE_NAME - Static variable in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated. The name of the index file.
indexFamilyOptionName - Static variable in class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
 
infiniteStartKey - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
infiniteStopKey - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
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.file.BloomFilterLayer.Reader
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
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
 
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.CountingIterator
 
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.DeletingIterator
 
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.FamilyIntersectingIterator
 
init(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.AgeOffFilter
 
init(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.ColumnAgeOffFilter
 
init(HashSet<Column>) - Method in class org.apache.accumulo.core.iterators.filter.ColumnQualifierFilter
 
init(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.ColumnQualifierFilter
 
init(Map<String, String>) - Method in interface org.apache.accumulo.core.iterators.filter.Filter
 
init(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.NoLabelFilter
 
init(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.RegExFilter
 
init(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.VisibilityFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FilteringIterator
 
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.GrepIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.LargeRowFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.MultiIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.NoLabelIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.RegExIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.RowDeletingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ScanCache
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
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(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SourceSwitchingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.VersioningIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
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.DefaultFormatter
 
initialize(Iterable<Map.Entry<Key, Value>>, boolean) - Method in interface org.apache.accumulo.core.util.format.Formatter
 
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.
inputProtocolFactory() - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
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_URL - Static variable in class org.apache.accumulo.core.trace.TraceDump
 
instanceId - Variable in class org.apache.accumulo.core.security.thrift.AuthInfo
 
InstanceOperations - Class in org.apache.accumulo.core.client.admin
Provides a class for administering the accumulo instance
InstanceOperations(Instance, AuthInfo) - Constructor for class org.apache.accumulo.core.client.admin.InstanceOperations
 
instanceOperations() - Method in class org.apache.accumulo.core.client.Connector
Retrieves a 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
 
InstanceUserPassword - Class in org.apache.accumulo.core.trace
 
InstanceUserPassword(Instance, String, String) - Constructor for class org.apache.accumulo.core.trace.InstanceUserPassword
 
INTEGER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for an Integer
InterruptibleIterator - Interface in org.apache.accumulo.core.iterators
 
IntersectingIterator - Class in org.apache.accumulo.core.iterators
 
IntersectingIterator() - Constructor for class org.apache.accumulo.core.iterators.IntersectingIterator
 
IntersectingIterator(IntersectingIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.IntersectingIterator
 
IntersectingIterator.TermSource - Class in org.apache.accumulo.core.iterators
 
IntersectingIterator.TermSource(IntersectingIterator.TermSource) - Constructor for class org.apache.accumulo.core.iterators.IntersectingIterator.TermSource
 
IntersectingIterator.TermSource(SortedKeyValueIterator<Key, Value>, Text) - Constructor for class org.apache.accumulo.core.iterators.IntersectingIterator.TermSource
 
IntersectingIterator.TermSource(SortedKeyValueIterator<Key, Value>, Text, boolean) - Constructor for class org.apache.accumulo.core.iterators.IntersectingIterator.TermSource
 
inUse - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
invalidate(Key) - Method in class org.apache.accumulo.core.iterators.ScanCache
 
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(KeyExtent) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
 
invalidateCache() - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
 
invalidateCache(String) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
 
invalidateCache() - Static method in class org.apache.accumulo.core.conf.TableConfiguration
 
iprot_ - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
iprot_ - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
iprot_ - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
iprot_ - Variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
isBackedByArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
isBackedByArray() - Method in class org.apache.accumulo.core.data.ByteSequence
 
isBlockCompressed() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns true if records are block-compressed.
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
 
isCompressed() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns true if values are compressed.
isContiguousRange(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.util.MetadataTable
 
isCurrent() - Method in interface org.apache.accumulo.core.iterators.SourceSwitchingIterator.DataSource
 
isDebuggingEnabled() - Static method in class org.apache.accumulo.core.util.shell.Shell
 
isDeleted() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
isDeleted() - Method in class org.apache.accumulo.core.data.Key
 
isDisableGC() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
isEmpty() - Method in class org.apache.accumulo.core.constraints.Violations
 
isEmpty() - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
 
isEmpty() - Method in class org.apache.accumulo.core.security.Authorizations
 
isEmpty() - Method in class org.apache.accumulo.core.util.BinaryTree
 
isEndKeyInclusive() - Method in class org.apache.accumulo.core.data.Range
 
isFixedZooPropertyKey(Property) - Static method in enum org.apache.accumulo.core.conf.Property
 
isFullMajorCompaction() - Method in class org.apache.accumulo.core.iterators.DefaultIteratorEnvironment
 
isFullMajorCompaction() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
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(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
isIsolated() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
isLocked() - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
isLockHeld(ZooKeeper, ZooLock.LockID) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
isLockHeld(ZooCache, ZooLock.LockID) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
isMore() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
isMore() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
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
 
IsolatedScanner.RowBuffer - Interface in org.apache.accumulo.core.client
 
IsolatedScanner.RowBufferFactory - Interface in org.apache.accumulo.core.client
 
IsolationException - Exception in org.apache.accumulo.core.client.impl
 
IsolationException() - Constructor for exception org.apache.accumulo.core.client.impl.IsolationException
 
isPartNextKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
isSave() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
isSet(ClientService.changePassword_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
isSet(ClientService.changePassword_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
isSet(ClientService.createUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
isSet(ClientService.createUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
isSet(ClientService.dropUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
isSet(ClientService.dropUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
isSet(ClientService.finishBulkImport_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
isSet(ClientService.finishBulkImport_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
isSet(ClientService.listUsers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
isSet(ClientService.listUsers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
isSet(ClientService.prepareBulkImport_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
isSet(ClientService.prepareBulkImport_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
isSet(InitialMultiScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
isSet(InitialScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
 
isSet(IterInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
isSet(MapFileInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
isSet(MultiScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
isSet(ScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
isSet(TColumn._Fields) - Method in class org.apache.accumulo.core.data.thrift.TColumn
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
isSet(TConstraintViolationSummary._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
isSet(TKey._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKey
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
isSet(TKeyExtent._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
isSet(TKeyValue._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
isSet(TMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TMutation
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
isSet(TRange._Fields) - Method in class org.apache.accumulo.core.data.thrift.TRange
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.TRange
 
isSet(UpdateErrors._Fields) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
isSet(GcCycleStats._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
isSet(GCStatus._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
isSet(Compacting._Fields) - Method in class org.apache.accumulo.core.master.thrift.Compacting
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
isSet(LoggerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
isSet(MasterClientService.createTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
isSet(MasterClientService.createTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
isSet(MasterClientService.deleteTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
isSet(MasterClientService.deleteTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
isSet(MasterClientService.flushTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
isSet(MasterClientService.flushTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
isSet(MasterClientService.offlineTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
isSet(MasterClientService.offlineTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
isSet(MasterClientService.onlineTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
isSet(MasterClientService.onlineTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
isSet(MasterClientService.renameTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
isSet(MasterClientService.renameTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
isSet(MasterMonitorInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
isSet(RecoveryException._Fields) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
isSet(RecoveryStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
isSet(TableInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
isSet(TabletInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
isSet(TabletServerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
isSet(TabletSplit._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
isSet(AuthInfo._Fields) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
isSet(ThriftSecurityException._Fields) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
isSet(ActionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
isSet(ActiveScan._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
isSet(CompactionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
isSet(ConstraintViolationException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
isSet(LogFile._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
isSet(MutationLogger.close_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
isSet(MutationLogger.close_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
isSet(MutationLogger.create_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
isSet(MutationLogger.create_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
isSet(MutationLogger.defineTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
isSet(MutationLogger.defineTablet_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
isSet(MutationLogger.getClosedLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
isSet(MutationLogger.getClosedLogs_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
isSet(MutationLogger.log_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
isSet(MutationLogger.log_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
isSet(MutationLogger.logManyTablets_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
isSet(MutationLogger.logManyTablets_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
isSet(MutationLogger.minorCompactionFinished_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
isSet(MutationLogger.minorCompactionFinished_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
isSet(MutationLogger.minorCompactionStarted_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
isSet(MutationLogger.minorCompactionStarted_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
isSet(MutationLogger.remove_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
isSet(MutationLogger.startCopy_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
isSet(MutationLogger.startCopy_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
isSet(NoSuchLogIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
isSet(NoSuchScanIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
isSet(NotServingTabletException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
isSet(TabletClientService.applyUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
isSet(TabletClientService.setUpdateTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
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 asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
isSet(TabletClientService.useLoggers_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
isSet(TabletMutations._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
isSet(TabletStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
isSet(TestService.setTimeOffset_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
isSet(TestService.setTimeOffset_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
isSet(TooManyFilesException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
Returns true if field corresponding to fieldID is set (has been asigned a value) and false otherwise
isSet(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
isSetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
Returns true if field age is set (has been asigned a value) and false otherwise
isSetAggs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Returns true if field aggs is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
Returns true if field authorizations is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetCode() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
Returns true if field code is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetCopyProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field copyProgress is set (has been asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
Returns true if field credentials is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
Returns true if field credentials is set (has been asigned 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 asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
Returns true if field credentials is set (has been asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
Returns true if field credentials is set (has been asigned 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 asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
Returns true if field credentials is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
Returns true if field credentials is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
Returns true if field credentials is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
Returns true if field credentials is set (has been asigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
Returns true if field credentials is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetDir() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
Returns true if field dir is set (has been asigned a value) and false otherwise
isSetDisableGC() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
Returns true if field disableGC is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetErrPercent() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
Returns true if field errPercent is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
Returns true if field files is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetFqfn() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
Returns true if field fqfn is set (has been asigned a value) and false otherwise
isSetFqfn() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
Returns true if field fqfn is set (has been asigned 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 asigned a value) and false otherwise
isSetFullyQualifiedFileName() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
Returns true if field fullyQualifiedFileName is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetHost() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field host is set (has been asigned a value) and false otherwise
isSetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
Returns true if field id is set (has been asigned a value) and false otherwise
isSetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
Returns true if field id is set (has been asigned a value) and false otherwise
isSetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
Returns true if field id is set (has been asigned a value) and false otherwise
isSetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
Returns true if field id is set (has been asigned a value) and false otherwise
isSetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
Returns true if field id is set (has been asigned a value) and false otherwise
isSetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
Returns true if field id is set (has been asigned a value) and false otherwise
isSetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
Returns true if field id is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetInstanceId() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
Returns true if field instanceId is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
Returns true if field keyExtent is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetLockFile() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
Returns true if field lockFile is set (has been asigned a value) and false otherwise
isSetLogger() - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
Returns true if field logger is set (has been asigned a value) and false otherwise
isSetLoggers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field loggers is set (has been asigned a value) and false otherwise
isSetLoggers() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
Returns true if field loggers is set (has been asigned a value) and false otherwise
isSetLoggers() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
Returns true if field loggers is set (has been asigned 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 asigned a value) and false otherwise
isSetMajor() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field major is set (has been asigned a value) and false otherwise
isSetMajor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field major is set (has been asigned a value) and false otherwise
isSetMajorCount() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field majorCount is set (has been asigned a value) and false otherwise
isSetMajorElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field majorElapsed is set (has been asigned a value) and false otherwise
isSetMajorFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field majorFail is set (has been asigned a value) and false otherwise
isSetMajorNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field majorNum is set (has been asigned a value) and false otherwise
isSetMajorQueueSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field majorQueueSumDev is set (has been asigned a value) and false otherwise
isSetMajorQueueTime() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field majorQueueTime is set (has been asigned a value) and false otherwise
isSetMajorSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field majorSumDev is set (has been asigned a value) and false otherwise
isSetMapProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field mapProgress is set (has been asigned a value) and false otherwise
isSetMillis() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
Returns true if field millis is set (has been asigned a value) and false otherwise
isSetMinor() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
Returns true if field minor is set (has been asigned a value) and false otherwise
isSetMinor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field minor is set (has been asigned a value) and false otherwise
isSetMinorCount() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field minorCount is set (has been asigned a value) and false otherwise
isSetMinorElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field minorElapsed is set (has been asigned a value) and false otherwise
isSetMinorFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field minorFail is set (has been asigned a value) and false otherwise
isSetMinorNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field minorNum is set (has been asigned a value) and false otherwise
isSetMinorQueueSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field minorQueueSumDev is set (has been asigned a value) and false otherwise
isSetMinorQueueTime() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field minorQueueTime is set (has been asigned a value) and false otherwise
isSetMinorSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field minorSumDev is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
Returns true if field mutation is set (has been asigned a value) and false otherwise
isSetMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
Returns true if field mutation is set (has been asigned 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 asigned a value) and false otherwise
isSetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
Returns true if field mutations is set (has been asigned a value) and false otherwise
isSetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
Returns true if field mutations is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetName() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
Returns true if field name is set (has been asigned a value) and false otherwise
isSetName() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
Returns true if field name is set (has been asigned a value) and false otherwise
isSetNewTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
Returns true if field newTableName is set (has been asigned 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 asigned a value) and false otherwise
isSetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
Returns true if field nsli is set (has been asigned a value) and false otherwise
isSetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
Returns true if field nsli is set (has been asigned a value) and false otherwise
isSetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
Returns true if field nsli is set (has been asigned a value) and false otherwise
isSetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
Returns true if field nsli is set (has been asigned a value) and false otherwise
isSetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
Returns true if field nsli is set (has been asigned a value) and false otherwise
isSetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
Returns true if field nsli is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetNumEntries() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field numEntries is set (has been asigned 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 asigned a value) and false otherwise
isSetOldTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
Returns true if field oldTableName is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
Returns true if field password is set (has been asigned a value) and false otherwise
isSetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
Returns true if field password is set (has been asigned a value) and false otherwise
isSetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
Returns true if field password is set (has been asigned a value) and false otherwise
isSetPassword() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
Returns true if field password is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
Returns true if field queueSumDev is set (has been asigned 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 asigned a value) and false otherwise
isSetQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
Returns true if field queueTime is set (has been asigned 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 asigned a value) and false otherwise
isSetRecovery() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
Returns true if field recovery is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetReduceProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
Returns true if field reduceProgress is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
Returns true if field sec is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
Returns true if field sec is set (has been asigned 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 asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
Returns true if field sec is set (has been asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
Returns true if field sec is set (has been asigned 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 asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
Returns true if field sec is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
Returns true if field sec is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
Returns true if field sec is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
Returns true if field sec is set (has been asigned a value) and false otherwise
isSetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
Returns true if field seq is set (has been asigned a value) and false otherwise
isSetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
Returns true if field seq is set (has been asigned a value) and false otherwise
isSetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
Returns true if field seq is set (has been asigned a value) and false otherwise
isSetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
Returns true if field seq is set (has been asigned a value) and false otherwise
isSetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
Returns true if field seq is set (has been asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetSort() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
Returns true if field sort is set (has been asigned 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 asigned a value) and false otherwise
isSetSplit() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Returns true if field split is set (has been asigned 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 asigned a value) and false otherwise
isSetSplitElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field splitElapsed is set (has been asigned a value) and false otherwise
isSetSplitFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field splitFail is set (has been asigned a value) and false otherwise
isSetSplitNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field splitNum is set (has been asigned 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 asigned a value) and false otherwise
isSetSplitPoints() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Returns true if field splitPoints is set (has been asigned a value) and false otherwise
isSetSplitSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field splitSumDev is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetStats() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
Returns true if field stats is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetStatusMajor() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field statusMajor is set (has been asigned a value) and false otherwise
isSetStatusMinor() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field statusMinor is set (has been asigned a value) and false otherwise
isSetStatusSplit() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
Returns true if field statusSplit is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
Returns true if field success is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
Returns true if field success is set (has been asigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
Returns true if field success is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
Returns true if field tableName is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
Returns true if field tableName is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Returns true if field tableName is set (has been asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
Returns true if field tableName is set (has been asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
Returns true if field tableName is set (has been asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
Returns true if field tableName is set (has been asigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
Returns true if field tableName is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetTables() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Returns true if field tables is set (has been asigned 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 asigned a value) and false otherwise
isSetTablet() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
Returns true if field tablet is set (has been asigned a value) and false otherwise
isSetTabletID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
Returns true if field tabletID is set (has been asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
Returns true if field tid is set (has been asigned a value) and false otherwise
isSetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
Returns true if field tid is set (has been asigned a value) and false otherwise
isSetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
Returns true if field tid is set (has been asigned a value) and false otherwise
isSetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
Returns true if field tid is set (has been asigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TKey
Returns true if field timestamp is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
Returns true if field tinfo is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
Returns true if field tinfo is set (has been asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
Returns true if field tinfo is set (has been asigned 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 asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
Returns true if field tinfo is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
Returns true if field tinfo is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
Returns true if field tinfo is set (has been asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
Returns true if field tinfo is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
Returns true if field tinfo is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
Returns true if field tinfo is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
Returns true if field tope is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
Returns true if field tope is set (has been asigned 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 asigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
Returns true if field tope is set (has been asigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
Returns true if field tope is set (has been asigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
Returns true if field tope is set (has been asigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
Returns true if field tope is set (has been asigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
Returns true if field tope is set (has been asigned 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 asigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
Returns true if field tope is set (has been asigned 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 asigned 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 asigned a value) and false otherwise
isSetTserverSession() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
Returns true if field tserverSession is set (has been asigned a value) and false otherwise
isSetTt() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Returns true if field tt is set (has been asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
Returns true if field updateID is set (has been asigned 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 asigned a value) and false otherwise
isSetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
Returns true if field updateID is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
Returns true if field user is set (has been asigned a value) and false otherwise
isSetUser() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
Returns true if field user is set (has been asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned 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 asigned a value) and false otherwise
isSort() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
isSorted() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Is the TFile sorted?
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.authenticateUser_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
 
isValidFormat(String) - Method in enum org.apache.accumulo.core.conf.PropertyType
 
isValidTablePropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
 
isValidZooPropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
 
isValueLengthKnown() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Check whether it is safe to call getValueLength().
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.IntersectingIterator.TermSource
 
iter - Variable in class org.apache.accumulo.core.iterators.OrIterator.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 interface org.apache.accumulo.core.client.BatchScanner
Returns an iterator over an accumulo table.
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.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 interface org.apache.accumulo.core.client.IsolatedScanner.RowBuffer
 
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 interface org.apache.accumulo.core.client.Scanner
Returns an iterator over an accumulo table.
iterator() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
iterator() - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
iterator() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
iterator() - Method in class org.apache.accumulo.core.conf.TableConfiguration
 
iterator() - Method in class org.apache.accumulo.core.conf.ZooConfiguration
 
iterator() - Method in interface org.apache.accumulo.core.iterators.SourceSwitchingIterator.DataSource
 
iterator() - Method in class org.apache.accumulo.core.security.Authorizations
 
iterator() - Method in class org.apache.accumulo.core.util.shell.EscapeTokenizer
 
iterator() - Method in class org.apache.accumulo.core.util.shell.QuotedStringTokenizer
 
IteratorEnvironment - Interface in org.apache.accumulo.core.iterators
 
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.Translator
 
Key - Class in org.apache.accumulo.core.data
 
Key() - Constructor for class org.apache.accumulo.core.data.Key
 
Key(Text) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(Text, long) - Constructor for class org.apache.accumulo.core.data.Key
 
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
 
Key(Text, Text, Text) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(Text, Text, Text, Text) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(Text, Text, Text, long) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(Text, Text, Text, Text, long) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(CharSequence, CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(CharSequence, CharSequence, CharSequence, long) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(CharSequence, CharSequence, CharSequence, CharSequence, long) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(Key) - Constructor for class org.apache.accumulo.core.data.Key
 
Key(TKey) - Constructor for class org.apache.accumulo.core.data.Key
 
key - Variable in class org.apache.accumulo.core.data.KeyValue
 
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.setUpdateTablet_args
 
keyExtent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
KeyFunctor - Interface in org.apache.accumulo.core.file.keyfunctor
 
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
 
keySerializer - Variable in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated.  
KeyValue - Class in org.apache.accumulo.core.data
 
KeyValue(Key, byte[]) - Constructor for class org.apache.accumulo.core.data.KeyValue
 

L

LargeRowFilter - Class in org.apache.accumulo.core.iterators
This iterator suppresses rows that exceed a specified number of columns.
LargeRowFilter() - Constructor for class org.apache.accumulo.core.iterators.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
 
lastTabletRow - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
lazyReset - Variable in class org.apache.accumulo.core.iterators.VersioningIterator
 
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.file.blockfile.cache.CacheEntry
 
length() - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
list() - Method in class org.apache.accumulo.core.client.admin.TableOperations
Retrieve a list of tables in Accumulo.
list() - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Retrieve a list of tables in Accumulo.
list() - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
LIST_SPANS - Static variable in class org.apache.accumulo.core.trace.TraceDump
 
listUsers() - Method in class org.apache.accumulo.core.client.admin.SecurityOperations
Return a list of users in accumulo
listUsers() - Method in class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
Return a list of users in accumulo
listUsers(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
listUsers(TInfo, AuthInfo) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
listUsers() - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
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<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
loadTablet(TInfo, AuthInfo, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
loadTablet(TInfo, AuthInfo, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
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
 
locateTablet(Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
 
locateTablet(Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
 
locateTablet(Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
locateTablet(Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.mock.MockTabletLocator
 
locationObtainer - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_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_PREFIX - Static variable in class org.apache.accumulo.core.zookeeper.ZooLock
 
lockAsync(ZooLock.AsyncLockWatcher, byte[]) - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
lockFile - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
log - Static variable in class org.apache.accumulo.core.iterators.IntersectingIterator
 
log - Static variable in class org.apache.accumulo.core.iterators.OrIterator
 
log(TInfo, long, long, int, TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
log(TInfo, long, long, int, TMutation) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
LogEntry - Class in org.apache.accumulo.core.tabletserver.log
 
LogEntry() - Constructor for class org.apache.accumulo.core.tabletserver.log.LogEntry
 
LogFile - Class in org.apache.accumulo.core.tabletserver.thrift
 
LogFile() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
LogFile(String, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
LogFile(LogFile) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.LogFile
Performs a deep copy on other.
LogFile._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.
logger - Variable in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
loggers - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
loggers - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
loggers - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
LoggerStatus - Class in org.apache.accumulo.core.master.thrift
 
LoggerStatus() - Constructor for class org.apache.accumulo.core.master.thrift.LoggerStatus
 
LoggerStatus(String) - Constructor for class org.apache.accumulo.core.master.thrift.LoggerStatus
 
LoggerStatus(LoggerStatus) - Constructor for class org.apache.accumulo.core.master.thrift.LoggerStatus
Performs a deep copy on other.
LoggerStatus._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.
LoggingRunnable - Class in org.apache.accumulo.core.util
 
LoggingRunnable(Logger, Runnable) - Constructor for class org.apache.accumulo.core.util.LoggingRunnable
 
logManyTablets(TInfo, long, List<TabletMutations>) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
logManyTablets(TInfo, long, List<TabletMutations>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
logSet - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
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
 
LongSummation - Class in org.apache.accumulo.core.iterators.aggregation
 
LongSummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.LongSummation
 
longToBytes(long) - Static method in class org.apache.accumulo.core.data.Value
Convert a long value to a byte array
longToBytes(long) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
 
longToBytes(long) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
 
lookupInstanceName(ZooCache, UUID) - Static method in class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
lookups - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
lookupTablet(TabletLocator.TabletLocation, Text, Text, TabletLocator) - Method in class org.apache.accumulo.core.client.impl.MetadataLocationObtainer
 
lookupTablet(TabletLocator.TabletLocation, Text, Text, TabletLocator) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletLocationObtainer
 
lookupTablets(String, Map<KeyExtent, List<Range>>, TabletLocator) - Method in class org.apache.accumulo.core.client.impl.MetadataLocationObtainer
 
lookupTablets(String, Map<KeyExtent, List<Range>>, TabletLocator) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletLocationObtainer
 
lostLock(ZooLock.LockLossReason) - Method in interface org.apache.accumulo.core.zookeeper.ZooLock.LockWatcher
 
lowerBound(byte[]) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Move the cursor to the first entry whose key is greater than or equal to the input key.
lowerBound(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Move the cursor to the first entry whose key is greater than or equal to the input key.
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.client.impl.HdfsZooInstance
 
main(String[]) - Static method in class org.apache.accumulo.core.client.impl.Trie
 
main(String[]) - Static method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
main(String[]) - Static method in class org.apache.accumulo.core.file.BloomFilterLayer
 
main(String[]) - Static method in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated.  
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.bcfile.TFile
Dumping the TFile information.
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.RFile
 
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.AcquireNewTable
 
main(String[]) - Static method in class org.apache.accumulo.core.util.LoggingRunnable
 
main(String[]) - Static method in class org.apache.accumulo.core.util.shell.Shell
 
main(String[]) - Static method in class org.apache.accumulo.core.zookeeper.ZooLock
 
major - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
major - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
majorCount - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
majorElapsed - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
majorFail - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
majorNum - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
majorQueueSumDev - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
majorQueueTime - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
majorSumDev - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
makeComparator(String) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.TFile
Make a raw comparator from a string name.
MAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
Overhead for entry in map
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.
MapFileOperations - Class in org.apache.accumulo.core.file.map
Deprecated. since 1.3
MapFileOperations() - Constructor for class org.apache.accumulo.core.file.map.MapFileOperations
Deprecated.  
MapFileOperations.RangeIterator - Class in org.apache.accumulo.core.file.map
Deprecated.  
MapFileOperations.RangeIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
mapFileSeekScanCompareTime - Static variable in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated.  
mapFileSeekScans - Static variable in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated.  
mapFileSeekScanTime - Static variable in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated.  
mapFileSeekTimeStat - Static variable in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated.  
MapFileUtil - Class in org.apache.accumulo.core.file.map
Deprecated. since 1.3
MapFileUtil() - Constructor for class org.apache.accumulo.core.file.map.MapFileUtil
Deprecated.  
mapProgress - Variable in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
MASTER_TABLETSERVER_CONNECTION_TIMEOUT - Static variable in class org.apache.accumulo.core.Constants
 
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.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.createTable_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.createTable_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
MasterClientService.createTable_args(TInfo, AuthInfo, String, List<byte[]>, Map<String, String>, TimeType) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
MasterClientService.createTable_args(MasterClientService.createTable_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
Performs a deep copy on other.
MasterClientService.createTable_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.createTable_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.createTable_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
MasterClientService.createTable_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
MasterClientService.createTable_result(MasterClientService.createTable_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
Performs a deep copy on other.
MasterClientService.createTable_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.deleteTable_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.deleteTable_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
MasterClientService.deleteTable_args(TInfo, AuthInfo, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
MasterClientService.deleteTable_args(MasterClientService.deleteTable_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
Performs a deep copy on other.
MasterClientService.deleteTable_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.deleteTable_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.deleteTable_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
MasterClientService.deleteTable_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
MasterClientService.deleteTable_result(MasterClientService.deleteTable_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
Performs a deep copy on other.
MasterClientService.deleteTable_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.flushTable_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.flushTable_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
MasterClientService.flushTable_args(TInfo, AuthInfo, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
MasterClientService.flushTable_args(MasterClientService.flushTable_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
Performs a deep copy on other.
MasterClientService.flushTable_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.flushTable_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.flushTable_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
MasterClientService.flushTable_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
MasterClientService.flushTable_result(MasterClientService.flushTable_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
Performs a deep copy on other.
MasterClientService.flushTable_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.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, AuthInfo) - 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.offlineTable_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.offlineTable_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
MasterClientService.offlineTable_args(TInfo, AuthInfo, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
MasterClientService.offlineTable_args(MasterClientService.offlineTable_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
Performs a deep copy on other.
MasterClientService.offlineTable_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.offlineTable_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.offlineTable_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
MasterClientService.offlineTable_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
MasterClientService.offlineTable_result(MasterClientService.offlineTable_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
Performs a deep copy on other.
MasterClientService.offlineTable_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.onlineTable_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.onlineTable_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
MasterClientService.onlineTable_args(TInfo, AuthInfo, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
MasterClientService.onlineTable_args(MasterClientService.onlineTable_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
Performs a deep copy on other.
MasterClientService.onlineTable_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.onlineTable_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.onlineTable_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
 
MasterClientService.onlineTable_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
 
MasterClientService.onlineTable_result(MasterClientService.onlineTable_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
Performs a deep copy on other.
MasterClientService.onlineTable_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 - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.Processor(MasterClientService.Iface) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor
 
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, AuthInfo, 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, AuthInfo, 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.renameTable_args - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.renameTable_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
MasterClientService.renameTable_args(TInfo, AuthInfo, String, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
MasterClientService.renameTable_args(MasterClientService.renameTable_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
Performs a deep copy on other.
MasterClientService.renameTable_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.renameTable_result - Class in org.apache.accumulo.core.master.thrift
 
MasterClientService.renameTable_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
 
MasterClientService.renameTable_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
 
MasterClientService.renameTable_result(MasterClientService.renameTable_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
Performs a deep copy on other.
MasterClientService.renameTable_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, AuthInfo, 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, AuthInfo, 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, AuthInfo, 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.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, AuthInfo, 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, AuthInfo, 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, AuthInfo, 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, AuthInfo, String) - 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.
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>, List<RecoveryStatus>, List<LoggerStatus>, MasterState, MasterGoalState, int, Set<String>) - 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
 
MAX_CF_IN_DLG - Static variable in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
MAX_COLUMNS - Static variable in class org.apache.accumulo.core.iterators.LargeRowFilter
 
MAX_DATA_TO_PRINT - Static variable in class org.apache.accumulo.core.Constants
 
maximizeStartKeyTimeStamp(Range) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
 
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(List<MySequenceFile.Sorter.SegmentDescriptor>, Path) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Merges the list of segments of type SegmentDescriptor
merge(Path[], boolean, Path) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Merges the contents of files passed in Path[] using a max factor value that is already set
merge(Path[], boolean, int, Path) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Merges the contents of files passed in Path[]
merge(Path[], Path, boolean) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Merges the contents of files passed in Path[]
merge(Path[], Path) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Merge the provided files.
merge(ColumnVisibility, Authorizations) - Method in interface org.apache.accumulo.core.security.VisibilityInterpreter
 
merge(VisibilityInterpreter) - Method in interface org.apache.accumulo.core.security.VisibilityInterpreter
 
mergeOverlapping(Collection<Range>) - Static method in class org.apache.accumulo.core.data.Range
 
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
 
METADATA_CURRENT_LOCATION_COLUMN_FAMILY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_DATAFILE_COLUMN_FAMILY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_DELETE_FLAG_PREFIX - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_DELETES_KEYSPACE - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_DIRECTORY_COLUMN - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_FUTURE_LOCATION_COLUMN_FAMILY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_KEYSPACE - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_LAST_LOCATION_COLUMN_FAMILY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_LOCK_COLUMN - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_LOG_COLUMN_FAMILY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_OLD_PREV_ROW_COLUMN - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_PREV_ROW_COLUMN - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_RESERVED_KEYSPACE - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_RESERVED_KEYSPACE_START_KEY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_RESERVED_KEYSPACE_STOP_KEY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_SCANFILE_COLUMN_FAMILY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_SERVER_COLUMN_FAMILY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_SPLIT_RATIO_COLUMN - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_TABLE_ID - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_TABLE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_TABLET_COLUMN_FAMILY - Static variable in class org.apache.accumulo.core.Constants
 
METADATA_TIME_COLUMN - Static variable in class org.apache.accumulo.core.Constants
 
MetadataLocationObtainer - Class in org.apache.accumulo.core.client.impl
 
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.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.changePassword_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.TColumn
 
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.LoggerStatus
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo
 
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.AuthInfo
 
metaDataMap - Static variable in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_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.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.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.flush_args
 
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.loadTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
MetadataTable - Class in org.apache.accumulo.core.util
 
MetadataTable() - Constructor for class org.apache.accumulo.core.util.MetadataTable
 
MetadataTable.DataFileValue - Class in org.apache.accumulo.core.util
 
MetadataTable.DataFileValue(long, long) - Constructor for class org.apache.accumulo.core.util.MetadataTable.DataFileValue
 
MetadataTable.DataFileValue(byte[]) - Constructor for class org.apache.accumulo.core.util.MetadataTable.DataFileValue
 
midKey() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Get the key at approximately the middle of the file.
millis - Variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
MIN_MASTER_LOOP_TIME - Static variable in class org.apache.accumulo.core.Constants
 
minor - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
minor - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
minorCompactionFinished(TInfo, long, long, int, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
minorCompactionFinished(TInfo, long, long, int, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
minorCompactionStarted(TInfo, long, long, int, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
minorCompactionStarted(TInfo, long, long, int, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
minorCount - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
minorElapsed - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
minorFail - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
minorNum - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
minorQueueSumDev - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
minorQueueTime - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
minorSumDev - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
miss() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
 
MockAccumulo - Class in org.apache.accumulo.core.client.mock
 
MockAccumulo() - Constructor for class org.apache.accumulo.core.client.mock.MockAccumulo
 
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
 
MockInstance() - Constructor for class org.apache.accumulo.core.client.mock.MockInstance
 
MockInstance(String) - Constructor for class org.apache.accumulo.core.client.mock.MockInstance
 
MockMultiTableBatchWriter - Class in org.apache.accumulo.core.client.mock
 
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
 
MockTable - Class in org.apache.accumulo.core.client.mock
 
MockTableOperations - Class in org.apache.accumulo.core.client.mock
 
MockTabletLocator - Class in org.apache.accumulo.core.client.mock
 
MockTabletLocator() - Constructor for class org.apache.accumulo.core.client.mock.MockTabletLocator
 
MockUser - Class in org.apache.accumulo.core.client.mock
 
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
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.MultiIterator
 
MultiIterator(List<SortedKeyValueIterator<Key, Value>>, KeyExtent) - Constructor for class org.apache.accumulo.core.iterators.MultiIterator
 
MultiIterator(List<SortedKeyValueIterator<Key, Value>>, boolean) - Constructor for class org.apache.accumulo.core.iterators.MultiIterator
 
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, AuthInfo, long, long, int) - Constructor for class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
 
Mutation - Class in org.apache.accumulo.core.data
Mutation represents an action that manipulates a row in a table Convenience methods which takes columns and value as CharSequence (String implements CharSequence) are provided.
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.tabletserver.thrift.MutationLogger.log_args
 
mutation - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
mutation - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
MutationLogger - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger
 
MutationLogger.Client - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.Client(TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
MutationLogger.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
MutationLogger.Client.Factory - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.Client.Factory() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client.Factory
 
MutationLogger.close_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.close_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
MutationLogger.close_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
MutationLogger.close_args(MutationLogger.close_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
Performs a deep copy on other.
MutationLogger.close_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.
MutationLogger.close_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.close_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
MutationLogger.close_result(NoSuchLogIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
MutationLogger.close_result(MutationLogger.close_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
Performs a deep copy on other.
MutationLogger.close_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.
MutationLogger.create_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.create_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
MutationLogger.create_args(TInfo, AuthInfo, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
MutationLogger.create_args(MutationLogger.create_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
Performs a deep copy on other.
MutationLogger.create_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.
MutationLogger.create_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.create_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
MutationLogger.create_result(LogFile, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
MutationLogger.create_result(MutationLogger.create_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
Performs a deep copy on other.
MutationLogger.create_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.
MutationLogger.defineTablet_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.defineTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
MutationLogger.defineTablet_args(TInfo, long, long, int, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
MutationLogger.defineTablet_args(MutationLogger.defineTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
Performs a deep copy on other.
MutationLogger.defineTablet_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.
MutationLogger.defineTablet_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.defineTablet_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
MutationLogger.defineTablet_result(NoSuchLogIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
MutationLogger.defineTablet_result(MutationLogger.defineTablet_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
Performs a deep copy on other.
MutationLogger.defineTablet_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.
MutationLogger.getClosedLogs_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.getClosedLogs_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
MutationLogger.getClosedLogs_args(TInfo, AuthInfo) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
MutationLogger.getClosedLogs_args(MutationLogger.getClosedLogs_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
Performs a deep copy on other.
MutationLogger.getClosedLogs_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.
MutationLogger.getClosedLogs_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.getClosedLogs_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
MutationLogger.getClosedLogs_result(List<String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
MutationLogger.getClosedLogs_result(MutationLogger.getClosedLogs_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
Performs a deep copy on other.
MutationLogger.getClosedLogs_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.
MutationLogger.Iface - Interface in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.log_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.log_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
MutationLogger.log_args(TInfo, long, long, int, TMutation) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
MutationLogger.log_args(MutationLogger.log_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
Performs a deep copy on other.
MutationLogger.log_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.
MutationLogger.log_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.log_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
MutationLogger.log_result(NoSuchLogIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
MutationLogger.log_result(MutationLogger.log_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
Performs a deep copy on other.
MutationLogger.log_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.
MutationLogger.logManyTablets_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.logManyTablets_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
MutationLogger.logManyTablets_args(TInfo, long, List<TabletMutations>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
MutationLogger.logManyTablets_args(MutationLogger.logManyTablets_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
Performs a deep copy on other.
MutationLogger.logManyTablets_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.
MutationLogger.logManyTablets_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.logManyTablets_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
MutationLogger.logManyTablets_result(NoSuchLogIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
MutationLogger.logManyTablets_result(MutationLogger.logManyTablets_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
Performs a deep copy on other.
MutationLogger.logManyTablets_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.
MutationLogger.minorCompactionFinished_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.minorCompactionFinished_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
MutationLogger.minorCompactionFinished_args(TInfo, long, long, int, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
MutationLogger.minorCompactionFinished_args(MutationLogger.minorCompactionFinished_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
Performs a deep copy on other.
MutationLogger.minorCompactionFinished_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.
MutationLogger.minorCompactionFinished_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.minorCompactionFinished_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
MutationLogger.minorCompactionFinished_result(NoSuchLogIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
MutationLogger.minorCompactionFinished_result(MutationLogger.minorCompactionFinished_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
Performs a deep copy on other.
MutationLogger.minorCompactionFinished_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.
MutationLogger.minorCompactionStarted_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.minorCompactionStarted_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
MutationLogger.minorCompactionStarted_args(TInfo, long, long, int, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
MutationLogger.minorCompactionStarted_args(MutationLogger.minorCompactionStarted_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
Performs a deep copy on other.
MutationLogger.minorCompactionStarted_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.
MutationLogger.minorCompactionStarted_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.minorCompactionStarted_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
MutationLogger.minorCompactionStarted_result(NoSuchLogIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
MutationLogger.minorCompactionStarted_result(MutationLogger.minorCompactionStarted_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
Performs a deep copy on other.
MutationLogger.minorCompactionStarted_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.
MutationLogger.Processor - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.Processor(MutationLogger.Iface) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Processor
 
MutationLogger.Processor.ProcessFunction - Interface in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.remove_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.remove_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
MutationLogger.remove_args(TInfo, AuthInfo, List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
MutationLogger.remove_args(MutationLogger.remove_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
Performs a deep copy on other.
MutationLogger.remove_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.
MutationLogger.startCopy_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.startCopy_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
MutationLogger.startCopy_args(TInfo, AuthInfo, String, String, boolean) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
MutationLogger.startCopy_args(MutationLogger.startCopy_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
Performs a deep copy on other.
MutationLogger.startCopy_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.
MutationLogger.startCopy_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
MutationLogger.startCopy_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
MutationLogger.startCopy_result(long, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
MutationLogger.startCopy_result(MutationLogger.startCopy_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
Performs a deep copy on other.
MutationLogger.startCopy_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.
mutations - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
mutations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
MutationsRejectedException - Exception in org.apache.accumulo.core.client
Communicate the failed mutations of a BatchWriter back to the client.
MutationsRejectedException(List<ConstraintViolationSummary>, ArrayList<KeyExtent>, Collection<String>, int) - Constructor for exception org.apache.accumulo.core.client.MutationsRejectedException
 
MyMapFile - Class in org.apache.accumulo.core.file.map
Deprecated. Use RFile
MyMapFile() - Constructor for class org.apache.accumulo.core.file.map.MyMapFile
Deprecated.  
MyMapFile.Reader - Class in org.apache.accumulo.core.file.map
Deprecated. Provide access to an existing map.
MyMapFile.Reader(FileSystem, String, Configuration) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Construct a map reader for the named map.
MyMapFile.Reader(FileSystem, String, WritableComparator, Configuration) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Construct a map reader for the named map using the named comparator.
MyMapFile.Reader(FileSystem, String, WritableComparator, Configuration, boolean) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Hook to allow subclasses to defer opening streams until further initialization is complete.
MyMapFile.Writer - Class in org.apache.accumulo.core.file.map
Deprecated. Writes a new map.
MyMapFile.Writer(Configuration, FileSystem, String, Class, Class) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Create the named map for keys of the named class.
MyMapFile.Writer(Configuration, FileSystem, String, Class, Class, MySequenceFile.CompressionType, Progressable) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Create the named map for keys of the named class.
MyMapFile.Writer(Configuration, FileSystem, String, Class, Class, MySequenceFile.CompressionType, CompressionCodec, Progressable) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Create the named map for keys of the named class.
MyMapFile.Writer(Configuration, FileSystem, String, Class, Class, MySequenceFile.CompressionType) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Create the named map for keys of the named class.
MyMapFile.Writer(Configuration, FileSystem, String, WritableComparator, Class) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Create the named map using the named key comparator.
MyMapFile.Writer(Configuration, FileSystem, String, WritableComparator, Class, MySequenceFile.CompressionType) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Create the named map using the named key comparator.
MyMapFile.Writer(Configuration, FileSystem, String, WritableComparator, Class, MySequenceFile.CompressionType, Progressable) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Create the named map using the named key comparator.
MyMapFile.Writer(Configuration, FileSystem, String, WritableComparator, Class, MySequenceFile.CompressionType, CompressionCodec, Progressable) - Constructor for class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Create the named map using the named key comparator.
MySequenceFile - Class in org.apache.accumulo.core.file.map
Deprecated. Use RFile
MySequenceFile.CompressionType - Enum in org.apache.accumulo.core.file.map
Deprecated. The compression type used to compress key/value pairs in the MySequenceFile.
MySequenceFile.Metadata - Class in org.apache.accumulo.core.file.map
Deprecated. The class encapsulating with the metadata of a file.
MySequenceFile.Metadata() - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Metadata
Deprecated.  
MySequenceFile.Metadata(TreeMap<Text, Text>) - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Metadata
Deprecated.  
MySequenceFile.Reader - Class in org.apache.accumulo.core.file.map
Deprecated. Reads key/value pairs from a sequence-format file.
MySequenceFile.Reader(FileSystem, Path, Configuration) - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Open the named file.
MySequenceFile.Sorter - Class in org.apache.accumulo.core.file.map
Deprecated. Sorts key/value pairs in a sequence-format file.
MySequenceFile.Sorter(FileSystem, Class<? extends WritableComparable>, Class, Configuration) - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Sort and merge files containing the named classes.
MySequenceFile.Sorter(FileSystem, RawComparator, Class, Class, Configuration) - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Sort and merge using an arbitrary RawComparator.
MySequenceFile.Sorter.RawKeyValueIterator - Interface in org.apache.accumulo.core.file.map
Deprecated. The interface to iterate over raw keys/values of SequenceFiles.
MySequenceFile.Sorter.SegmentDescriptor - Class in org.apache.accumulo.core.file.map
Deprecated. This class defines a merge segment.
MySequenceFile.Sorter.SegmentDescriptor(long, long, Path) - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated. Constructs a segment
MySequenceFile.ValueBytes - Interface in org.apache.accumulo.core.file.map
Deprecated. The interface to 'raw' values of SequenceFiles.
MySequenceFile.Writer - Class in org.apache.accumulo.core.file.map
Deprecated. Write key/value pairs to a sequence-format file.
MySequenceFile.Writer(FileSystem, Configuration, Path, Class, Class) - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Create the named file.
MySequenceFile.Writer(FileSystem, Configuration, Path, Class, Class, Progressable, MySequenceFile.Metadata) - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Create the named file with write-progress reporter.
MySequenceFile.Writer(FileSystem, Configuration, Path, Class, Class, int, short, long, Progressable, MySequenceFile.Metadata) - Constructor for class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. Create the named file with write-progress reporter.

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 - Variable in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
name - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
namedOptions - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
nbHash - Variable in class org.apache.accumulo.core.bloomfilter.Filter
The number of hash function to consider.
newBuffer() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBufferFactory
 
newBuffer() - Method in interface org.apache.accumulo.core.client.IsolatedScanner.RowBufferFactory
 
newTableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
newTablets - Variable in class org.apache.accumulo.core.master.thrift.TabletSplit
 
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.file.BloomFilterLayer.Reader
 
next() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
Deprecated.  
next(WritableComparable, Writable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Read the next key/value pair in the map into key and val.
next() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
next(Writable) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Read the next key in the file into key, skipping its value.
next(Writable, Writable) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Read the next key/value pair in the file into key and val.
next(DataOutputBuffer) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Call MySequenceFile.Reader.nextRaw(DataOutputBuffer,MySequenceFile.ValueBytes).
next(Object) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Read the next key in the file, skipping its value.
next() - Method in interface org.apache.accumulo.core.file.map.MySequenceFile.Sorter.RawKeyValueIterator
Deprecated. Sets up the current key and value (for getKey and getValue)
next() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
next() - Method in class org.apache.accumulo.core.iterators.CountingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.DeletingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.DevNull
 
next() - Method in class org.apache.accumulo.core.iterators.FilteringIterator
 
next() - Method in class org.apache.accumulo.core.iterators.HeapIterator
 
next() - Method in class org.apache.accumulo.core.iterators.IntersectingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.LargeRowFilter
 
next() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
next() - Method in class org.apache.accumulo.core.iterators.RowDeletingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.ScanCache
 
next() - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
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.SourceSwitchingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.VersioningIterator
 
next() - Method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
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.DefaultFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.DeleterFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
 
nextRaw(DataOutputBuffer, MySequenceFile.ValueBytes) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Read 'raw' records.
nextRawKey(DataOutputBuffer) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Read 'raw' keys.
nextRawKey() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated. Fills up the rawKey object with the key returned by the Reader
nextRawValue(MySequenceFile.ValueBytes) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Read 'raw' values.
nextRawValue(MySequenceFile.ValueBytes) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated. Fills up the passed rawValue with the value corresponding to the key read earlier
NO_AUTHS - Static variable in class org.apache.accumulo.core.Constants
 
nodes - Variable in class org.apache.accumulo.core.trace.SpanTree
 
NoLabelFilter - Class in org.apache.accumulo.core.iterators.filter
 
NoLabelFilter() - Constructor for class org.apache.accumulo.core.iterators.filter.NoLabelFilter
 
NoLabelIterator - Class in org.apache.accumulo.core.iterators
 
NoLabelIterator() - Constructor for class org.apache.accumulo.core.iterators.NoLabelIterator
 
NoSuchLogIDException - Exception in org.apache.accumulo.core.tabletserver.thrift
 
NoSuchLogIDException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
NoSuchLogIDException(NoSuchLogIDException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
Performs a deep copy on other.
NoSuchLogIDException._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.
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.
notFlag - Variable in class org.apache.accumulo.core.iterators.IntersectingIterator.TermSource
 
notFlagOptionName - Static variable in class org.apache.accumulo.core.iterators.IntersectingIterator
 
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.
nsli - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
nsli - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
nsli - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
nsli - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
nsli - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
nsli - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
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.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.IntersectingIterator
 
num - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.AboutCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.AddSplitsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.AuthenticateCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.ClasspathCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.ClearCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.ConfigCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.CreateTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.CreateUserCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.DebugCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteScanIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.DropUserCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.ExecfileCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.ExitCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.FlushCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.FormatterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.GetAuthsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.GetGroupsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.GetSplitsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.GrantCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.GrepCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.HelpCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.HiddenCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.ImportDirectoryCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.InsertCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.ListScansCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.MasterStateCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.PasswdCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.RenameTableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.RevokeCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.SelectCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.SelectrowCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.SetAuthsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.SetGroupsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.SetIterCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.SystemPermissionsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.TableCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.TablePermissionsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.TablesCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.UserCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.UserPermissionsCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.UsersCommand
 
numArgs() - Method in class org.apache.accumulo.core.util.shell.Shell.WhoAmICommand
 
NumArraySummation - Class in org.apache.accumulo.core.iterators.aggregation
 
NumArraySummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
 
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.master.thrift.TabletInfo
 
numEntries - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
NumSummation - Class in org.apache.accumulo.core.iterators.aggregation
 
NumSummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.NumSummation
 

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)
offline(String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
offline(String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
offline(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
offlineTable(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
offlineTable(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
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_PACKAGE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
oldTableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
oldTablet - Variable in class org.apache.accumulo.core.master.thrift.TabletSplit
 
online(String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
online(String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
online(String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
onlineTable(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
onlineTable(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
onlineTablets - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
 
op - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
open(FileSystem, String, WritableComparator, Configuration) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
openFile(FileSystem, Path, int, long) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Override this method to specialize the type of FSDataInputStream returned.
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
Deprecated.  
openIndex(String, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
Deprecated.  
openIndex(Configuration, FileSystem, Path) - Static method in class org.apache.accumulo.core.file.map.MapFileUtil
Deprecated.  
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
Deprecated.  
openMapFileWriter(AccumuloConfiguration, Configuration, FileSystem, String) - Static method in class org.apache.accumulo.core.file.map.MapFileUtil
Deprecated.  
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
Deprecated.  
openReader(String, Range, Set<ByteSequence>, boolean, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
Deprecated.  
openReader(String, Range, Set<ByteSequence>, boolean, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
Deprecated.  
openReader(String, boolean, FileSystem, Configuration, AccumuloConfiguration, BlockCache, BlockCache) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
Deprecated.  
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
Deprecated.  
openWriter(String, FileSystem, Configuration, AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
oprot_ - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
oprot_ - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
oprot_ - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
oprot_ - Variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
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
 
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
 
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.filter.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.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.mapreduce - package org.apache.accumulo.core.client.mapreduce
 
org.apache.accumulo.core.client.mapreduce.lib.partition - package org.apache.accumulo.core.client.mapreduce.lib.partition
 
org.apache.accumulo.core.client.mock - package org.apache.accumulo.core.client.mock
 
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.filter - package org.apache.accumulo.core.iterators.filter
 
org.apache.accumulo.core.master - package org.apache.accumulo.core.master
 
org.apache.accumulo.core.master.thrift - package org.apache.accumulo.core.master.thrift
 
org.apache.accumulo.core.security - package org.apache.accumulo.core.security
 
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.shell - package org.apache.accumulo.core.util.shell
 
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
 
outputProtocolFactory() - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
overrideCurrentTime(long) - Method in class org.apache.accumulo.core.iterators.filter.ColumnAgeOffFilter
 

P

Pair<A,B> - Class in org.apache.accumulo.core.util
 
Pair(A, B) - Constructor for class org.apache.accumulo.core.util.Pair
 
parent - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
parseAddress(String, int) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
parseAddress(Text, int) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
parseAddress(String, Property) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
PartialKey - Enum in org.apache.accumulo.core.data
 
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
 
password - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
password - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
password - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
password - Variable in class org.apache.accumulo.core.security.thrift.AuthInfo
 
password - Variable in class org.apache.accumulo.core.trace.InstanceUserPassword
 
PER_BLOCK_OVERHEAD - Static variable in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
 
PerColumnIteratorConfig - Class in org.apache.accumulo.core.iterators.conf
 
PerColumnIteratorConfig(Text, String) - Constructor for class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
 
PerColumnIteratorConfig(Text, Text, String) - Constructor for class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
 
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.revokeSystemPermission_args
 
permission - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
ping(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
ping(AuthInfo) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
prepareAppendKey(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Writer
Obtain an output stream for writing a key into TFile.
prepareAppendValue(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Writer
Obtain an output stream for writing a value into TFile.
prepareBulkImport(TInfo, AuthInfo, String, String, double) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
prepareBulkImport(TInfo, AuthInfo, String, String, double) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
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.
prepareMetaBlock(String, String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Writer
Obtain an output stream for creating a meta block.
prepareMetaBlock(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Writer
Obtain an output stream for creating a meta block.
preserveInput(boolean) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated. Whether to delete the files when no longer needed
prevEndRow - Variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
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.SystemPermission
 
printableValues() - Static method in enum org.apache.accumulo.core.security.TablePermission
 
printHelp() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
printIndex() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
printInfo() - Method in class org.apache.accumulo.core.client.impl.Trie
 
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
 
printMetaBlockInfo(Configuration, FileSystem, Path) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.PrintInfo
 
printRecords(CommandLine, Shell, Iterable<Map.Entry<Key, Value>>) - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
printStats() - Static method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
printTrace(Scanner, TraceDump.Printer) - Static method in class org.apache.accumulo.core.trace.TraceDump
 
priority - Variable in class org.apache.accumulo.core.data.thrift.IterInfo
 
process(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor
 
process(int, TProtocol, TProtocol) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ProcessFunction
 
process(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor
 
process(int, TProtocol, TProtocol) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.ProcessFunction
 
process(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor
 
process(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Processor
 
process(int, TProtocol, TProtocol) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Processor.ProcessFunction
 
process(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor
 
process(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.Processor
 
process(int, TProtocol, TProtocol) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TestService.Processor.ProcessFunction
 
process(WatchedEvent) - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
processMap_ - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor
 
processMap_ - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor
 
processMap_ - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Processor
 
processMap_ - Variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.Processor
 
propertiesChanged() - Method in interface org.apache.accumulo.core.conf.ConfigurationObserver
 
propertiesChanged(String) - Method in class org.apache.accumulo.core.conf.TableConfiguration
 
Property - Enum in org.apache.accumulo.core.conf
 
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.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.TableConfiguration
 
PropertyType - Enum in org.apache.accumulo.core.conf
 
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(Mutation, ColumnFQ, Value) - Static method in class org.apache.accumulo.core.util.ColumnFQ
 
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(Mutation, ColumnFQ) - Static method in class org.apache.accumulo.core.util.ColumnFQ
 
putPersistentData(String, byte[], ZooUtil.NodeExistsPolicy) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
Create a persistent node with the default ACL
putPersistentData(String, byte[], int, ZooUtil.NodeExistsPolicy) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
putPersistentData(ZooKeeper, String, byte[], ZooUtil.NodeExistsPolicy) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
Create a persistent node with the default ACL
putPersistentData(ZooKeeper, String, byte[], int, ZooUtil.NodeExistsPolicy) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
putToAggs(String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
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
 
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
 
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

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
 
queued - Variable in class org.apache.accumulo.core.master.thrift.Compacting
 
queueSumDev - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
queueSumDev - Variable in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
queueTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
queueTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
QuotedStringTokenizer - Class in org.apache.accumulo.core.util.shell
A basic tokenizer for generating tokens from a string.
QuotedStringTokenizer(String) - Constructor for class org.apache.accumulo.core.util.shell.QuotedStringTokenizer
 

R

Range - Class in org.apache.accumulo.core.data
 
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 inclusive to endRow inclusive
Range(CharSequence, boolean, CharSequence, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow inclusive to endRow inclusive
Range(Key, boolean, Key, boolean) - Constructor for class org.apache.accumulo.core.data.Range
 
Range(Range) - Constructor for class org.apache.accumulo.core.data.Range
Copy constructor
Range(Key, Key, boolean, boolean, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.Range
 
Range(TRange) - Constructor for class org.apache.accumulo.core.data.Range
 
range - Variable in class org.apache.accumulo.core.iterators.ColumnFamilySkippingIterator
 
range - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
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.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.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.changePassword_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.TColumn
 
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(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(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo
 
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(TProtocol) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
read(TProtocol) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_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.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.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.flush_args
 
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.loadTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
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.mapreduce.AccumuloInputFormat.RangeInputSplit
 
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.map.MySequenceFile.Metadata
Deprecated.  
readFields(DataInput) - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
readFields(DataInput) - Method in class org.apache.accumulo.core.file.rfile.RFile.IndexEntry
 
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.
readVLong(DataInput) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Decoding the variable-length integer.
receive(Key, Value) - Method in interface org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator.ResultReceiver
 
recovery - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
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, String, double, double, 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
 
recursiveCopyPersistent(String, String, ZooUtil.NodeExistsPolicy) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
recursiveCopyPersistent(ZooKeeper, String, String, ZooUtil.NodeExistsPolicy) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
recursiveDelete(String, ZooUtil.NodeMissingPolicy) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
This method will delete a node and all its children from zookeeper
recursiveDelete(ZooKeeper, String, ZooUtil.NodeMissingPolicy) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
 
recv_authenticateUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_bulkImport() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_changeAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_changePassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_close() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.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_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_create() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
recv_createTable() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_createUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_defineTablet() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
recv_deleteTable() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_dropUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_finishBulkImport() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_flushTable() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_getActiveScans() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
recv_getClosedLogs() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.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_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_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_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_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_listUsers() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_log() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
recv_logManyTablets() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
recv_minorCompactionFinished() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
recv_minorCompactionStarted() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
recv_offlineTable() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_onlineTable() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
recv_ping() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
recv_prepareBulkImport() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.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_renameTable() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.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_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_setTimeOffset() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.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_startCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.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_update() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
reduceFiles(Configuration, FileSystem, Text, Text, Collection<String>, int, String, int) - Static method in class org.apache.accumulo.core.file.FileUtil
 
reduceProgress - Variable in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
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.filter
 
RegExFilter() - Constructor for class org.apache.accumulo.core.iterators.filter.RegExFilter
 
RegExIterator - Class in org.apache.accumulo.core.iterators
 
RegExIterator() - Constructor for class org.apache.accumulo.core.iterators.RegExIterator
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.AuthenticateCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.DebugCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteTableCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.DropUserCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.GrantCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.HelpCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.RenameTableCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.RevokeCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.SetAuthsCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.TableCommand
 
registerCompletion(Token, Map<Shell.Command.CompletionSet, Set<String>>) - Method in class org.apache.accumulo.core.util.shell.Shell.UserCommand
 
registerCompletionForCommands(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
 
RelativeKey - Class in org.apache.accumulo.core.file.rfile
 
RelativeKey() - Constructor for class org.apache.accumulo.core.file.rfile.RelativeKey
 
RelativeKey(Key, Key) - Constructor for class org.apache.accumulo.core.file.rfile.RelativeKey
 
remove() - Method in class org.apache.accumulo.core.client.impl.ScannerIterator
 
remove() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator
 
remove(TInfo, AuthInfo, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
remove(TInfo, AuthInfo, List<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
remove() - Method in class org.apache.accumulo.core.trace.TraceFormatter
 
remove() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
removeObserver(ConfigurationObserver) - Method in class org.apache.accumulo.core.conf.TableConfiguration
 
removeProperty(String) - Method in class org.apache.accumulo.core.client.admin.InstanceOperations
Removes a instance property from zookeeper
removeProperty(String, String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
Removes a property from a table
removeProperty(String, String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Removes a property from a table
removeProperty(String, String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
removeSystemProperty(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
removeSystemProperty(TInfo, AuthInfo, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
removeTableProperty(TInfo, AuthInfo, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
removeTableProperty(TInfo, AuthInfo, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
rename(String, String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
Rename a table
rename(String, String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Rename a table
rename(String, String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
rename(FileSystem, String, String) - Static method in class org.apache.accumulo.core.file.map.MyMapFile
Deprecated. Renames an existing map directory.
renameTable(TInfo, AuthInfo, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
renameTable(TInfo, AuthInfo, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
reportSplitExtent(TInfo, AuthInfo, String, TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
reportSplitExtent(TInfo, AuthInfo, String, TabletSplit) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
reportTabletStatus(TInfo, AuthInfo, String, TabletLoadState, TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
reportTabletStatus(TInfo, AuthInfo, String, TabletLoadState, TKeyExtent) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
reserveMapFileReader(String) - Method in class org.apache.accumulo.core.iterators.DefaultIteratorEnvironment
 
reserveMapFileReader(String) - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
reset() - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Re-positions the reader before its first key.
reset() - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
 
reset() - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
 
reset(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
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(Object) - Static method in class org.apache.accumulo.core.util.ThriftUtil
 
returnTransport(TTransport) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
 
revokeSystemPermission(String, SystemPermission) - Method in class 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.admin.SecurityOperationsImpl
Revoke a system permission from a user
revokeSystemPermission(TInfo, AuthInfo, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
revokeSystemPermission(TInfo, AuthInfo, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
revokeSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
revokeTablePermission(String, String, TablePermission) - Method in class 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.admin.SecurityOperationsImpl
Revoke a table permission for a specific user on a specific table
revokeTablePermission(TInfo, AuthInfo, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
revokeTablePermission(TInfo, AuthInfo, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
 
revokeTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.client.mock.MockSecurityOperations
 
rewind() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Rewind to the first entry in the scanner.
RFile - Class in org.apache.accumulo.core.file.rfile
 
RFile.IndexEntry - Class in org.apache.accumulo.core.file.rfile
 
RFile.IndexEntry() - Constructor for class org.apache.accumulo.core.file.rfile.RFile.IndexEntry
 
RFile.Reader - Class in org.apache.accumulo.core.file.rfile
 
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
 
RFileOperations - Class in org.apache.accumulo.core.file.rfile
 
RFileOperations() - Constructor for class org.apache.accumulo.core.file.rfile.RFileOperations
 
ROOT_TABLET_EXTENT - Static variable in class org.apache.accumulo.core.Constants
 
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.filter.RegExFilter
 
RowDeletingIterator - Class in org.apache.accumulo.core.iterators
An iterator for deleting whole rows.
RowDeletingIterator() - Constructor for class org.apache.accumulo.core.iterators.RowDeletingIterator
 
RowFunctor - Class in org.apache.accumulo.core.file.keyfunctor
 
RowFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.RowFunctor
 
RT - Static variable in class org.apache.accumulo.core.client.impl.Translator
 
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
 
save - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
scan(Instance, AuthInfo, 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
 
ScanCache - Class in org.apache.accumulo.core.iterators
 
ScanCache(long, KeyExtent) - Constructor for class org.apache.accumulo.core.iterators.ScanCache
 
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.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
 
Scanner - Interface in org.apache.accumulo.core.client
Walk a table over a given range.
ScannerBase - Interface in org.apache.accumulo.core.client
This class host methods that are shared between all different types of scanners.
ScannerImpl - Class in org.apache.accumulo.core.client.impl
 
ScannerImpl(Instance, AuthInfo, String, Authorizations) - Constructor for class org.apache.accumulo.core.client.impl.ScannerImpl
 
ScannerIterator - Class in org.apache.accumulo.core.client.impl
 
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
 
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.
ScanState - Enum in org.apache.accumulo.core.client.admin
 
ScanState - Enum in org.apache.accumulo.core.tabletserver.thrift
 
ScanType - Enum in org.apache.accumulo.core.client.admin
 
ScanType - Enum in org.apache.accumulo.core.tabletserver.thrift
 
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.changeAuthorizations_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
sec - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_result
 
sec - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
SecurityErrorCode - Enum in org.apache.accumulo.core.security.thrift
 
SecurityOperations - Class in org.apache.accumulo.core.client.admin
Provides a class for managing users and permissions
SecurityOperations() - Constructor for class org.apache.accumulo.core.client.admin.SecurityOperations
 
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
 
SecurityOperationsImpl(Instance, AuthInfo) - Constructor for class org.apache.accumulo.core.client.admin.SecurityOperationsImpl
 
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
Deprecated.  
seek(WritableComparable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated. Positions the reader at the named key, or if none such exists, at the first entry after the named key.
seek(WritableComparable, WritableComparable) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
seek(long) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Set the current byte position in the input file.
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
 
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.ColumnFamilySkippingIterator
 
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.DeletingIterator
 
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.FamilyIntersectingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.FilteringIterator
 
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.IntersectingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.LargeRowFilter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.MultiIterator
 
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.RowDeletingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.ScanCache
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
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
An iterator must seek to the first key in the range taking inclusiveness into account.
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.SourceSwitchingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.VersioningIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.WholeRowIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
seekColumnFamilies - Variable in class org.apache.accumulo.core.iterators.IntersectingIterator
 
seekTo(byte[]) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Move the cursor to the first entry whose key is greater than or equal to the input key.
seekTo(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Move the cursor to the first entry whose key is greater than or equal to the input key.
seekToEnd() - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Seek to the end of the scanner.
send_applyUpdate(TInfo, long, TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_authenticateUser(TInfo, AuthInfo, String, byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_bulkImport(TInfo, AuthInfo, Map<TKeyExtent, Map<String, MapFileInfo>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_changeAuthorizations(TInfo, AuthInfo, String, List<byte[]>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_changePassword(TInfo, AuthInfo, String, byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_close(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.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_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_create(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_createTable(TInfo, AuthInfo, String, List<byte[]>, Map<String, String>, TimeType) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_createUser(TInfo, AuthInfo, String, byte[], List<byte[]>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_defineTablet(TInfo, long, long, int, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_deleteTable(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_dropUser(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_finishBulkImport(TInfo, AuthInfo, String, String, boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_flush(TInfo, AuthInfo, String, Set<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_flushTable(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_getActiveScans(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getClosedLogs(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_getHistoricalStats(TInfo, AuthInfo) - 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, AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_getRootTabletLocation() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_getStatus(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
send_getTabletServerStatus(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getTabletStats(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_getUserAuthorizations(TInfo, AuthInfo, 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_grantSystemPermission(TInfo, AuthInfo, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_grantTablePermission(TInfo, AuthInfo, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_halt(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_hasSystemPermission(TInfo, AuthInfo, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_hasTablePermission(TInfo, AuthInfo, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_listUsers(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_loadTablet(TInfo, AuthInfo, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_log(TInfo, long, long, int, TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_logManyTablets(TInfo, long, List<TabletMutations>) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_minorCompactionFinished(TInfo, long, long, int, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_minorCompactionStarted(TInfo, long, long, int, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_offlineTable(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_onlineTable(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_ping(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_prepareBulkImport(TInfo, AuthInfo, String, String, double) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_remove(TInfo, AuthInfo, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_removeSystemProperty(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_removeTableProperty(TInfo, AuthInfo, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_renameTable(TInfo, AuthInfo, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_reportSplitExtent(TInfo, AuthInfo, String, TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_reportTabletStatus(TInfo, AuthInfo, String, TabletLoadState, TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_revokeSystemPermission(TInfo, AuthInfo, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_revokeTablePermission(TInfo, AuthInfo, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
send_setMasterGoalState(TInfo, AuthInfo, MasterGoalState) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_setSystemProperty(TInfo, AuthInfo, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_setTableProperty(TInfo, AuthInfo, String, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_setTimeOffset(AuthInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
send_setUpdateTablet(TInfo, long, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_shutdown(TInfo, AuthInfo, boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_shutdownTabletServer(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
send_splitTablet(TInfo, AuthInfo, TKeyExtent, byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_startCopy(TInfo, AuthInfo, String, String, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
send_startMultiScan(TInfo, AuthInfo, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<byte[]>, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_startScan(TInfo, AuthInfo, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<byte[]>, boolean, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_startUpdate(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_unloadTablet(TInfo, AuthInfo, String, TKeyExtent, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_update(TInfo, AuthInfo, TKeyExtent, TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
send_useLoggers(TInfo, AuthInfo, Set<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
SEPARATOR_CHAR - Static variable in class org.apache.accumulo.core.util.ServerServices
 
seq - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
seq - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
seq - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
seq - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
seq - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
seqid_ - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
 
seqid_ - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
seqid_ - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
seqid_ - Variable in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
SequenceFileIterator - Class in org.apache.accumulo.core.iterators
Deprecated. since 1.3
SequenceFileIterator(MySequenceFile.Reader, boolean) - Constructor for class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
serialize() - Method in class org.apache.accumulo.core.security.Authorizations
 
serialize(String) - Method in class org.apache.accumulo.core.zookeeper.ZooLock.LockID
 
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
 
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
 
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
 
sessionExpired() - Method in interface org.apache.accumulo.core.conf.ConfigurationObserver
 
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
 
set(byte[]) - Method in class org.apache.accumulo.core.data.Value
 
set(Text, Text) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Metadata
Deprecated.  
set(byte[], int, int) - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
set(ByteSequence) - Method in class org.apache.accumulo.core.util.ByteArrayBackedCharSequence
 
setAge(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setAgeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setAggs(Map<String, String>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setAggsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setAuthorityIterator(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.ScanCache
 
setAuthorizationFailures(List<TKeyExtent>) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setAuthorizationFailuresIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
 
setAuthorizations(List<byte[]>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setAuthorizations(List<byte[]>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setAuthorizations(List<byte[]>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setAuthorizations(List<byte[]>) - 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.client.impl.thrift.ClientService.createUser_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
 
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.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
 
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
 
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
 
setClassName(String) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setClient(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setClientIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setCode(SecurityErrorCode) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
setCodeIsSet(boolean) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
setColFamily(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColFamilyIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColQualifier(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColQualifierIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColumnFamily(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnFamilyIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnFamilyRegex(String) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Set a column family regular expression that filters non matching entries server side.
setColumnFamilyRegex(String) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
setColumnFamilyRegex(String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Set a column family regular expression that filters non matching entries server side.
setColumnQualifier(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnQualifierIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColumnQualifierRegex(String) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Set a column qualifier regular expression that filters non matching entries server side.
setColumnQualifierRegex(String) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
setColumnQualifierRegex(String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Set a column qualifier regular expression that filters non matching entries server side.
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
 
setColumnVisibilityIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setColVisibility(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setColVisibilityIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKey
 
setCompressionType(Configuration, MySequenceFile.CompressionType) - Static method in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. Use the one of the many MySequenceFile.createWriter methods to specify the MySequenceFile.CompressionType while creating the MySequenceFile to specify the MySequenceFile.CompressionType for job-outputs.
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 class org.apache.accumulo.core.client.impl.HdfsZooInstance
 
setConfiguration(AccumuloConfiguration) - Method in interface org.apache.accumulo.core.client.Instance
set the AccumuloConfiguration to use when interacting with this instance
setConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.client.mock.MockInstance
 
setConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
 
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
 
setCopyProgress(double) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setCopyProgressIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setCount(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setCountIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
setCredentials(AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_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.changeAuthorizations_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.flush_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.splitTablet_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
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_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
 
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
 
setData(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setDataIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
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
 
setDescriptionIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setDir(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
setDirIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
setDisableGC(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
setDisableGCIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
setElapsed(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setElapsedIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
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
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setEntries(int) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setEntriesIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
setErrors(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setErrorsIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setErrPercent(double) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
setErrPercentIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
setEstimatedSize(long) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
setEstimatedSizeIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
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.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.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.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
 
setFactor(int) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Set the number of streams to merge at once.
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
 
setFieldValue(ClientService.authenticateUser_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
 
setFieldValue(ClientService.changeAuthorizations_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
 
setFieldValue(ClientService.changePassword_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setFieldValue(ClientService.changePassword_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
setFieldValue(ClientService.createUser_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setFieldValue(ClientService.createUser_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
setFieldValue(ClientService.dropUser_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
setFieldValue(ClientService.dropUser_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
setFieldValue(ClientService.finishBulkImport_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
setFieldValue(ClientService.finishBulkImport_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_result
 
setFieldValue(ClientService.getInstanceId_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
setFieldValue(ClientService.getRootTabletLocation_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
setFieldValue(ClientService.getUserAuthorizations_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setFieldValue(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
 
setFieldValue(ClientService.grantSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setFieldValue(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
 
setFieldValue(ClientService.hasSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setFieldValue(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setFieldValue(ClientService.listUsers_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_args
 
setFieldValue(ClientService.listUsers_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
setFieldValue(ClientService.ping_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
 
setFieldValue(ClientService.prepareBulkImport_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
setFieldValue(ClientService.prepareBulkImport_result._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
setFieldValue(ClientService.revokeSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setFieldValue(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
 
setFieldValue(ThriftTableOperationException._Fields, Object) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setFieldValue(int, Object) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setFieldValue(InitialMultiScan._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
 
setFieldValue(int, 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(int, 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(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
 
setFieldValue(TColumn._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.data.thrift.TColumn
 
setFieldValue(TConstraintViolationSummary._Fields, Object) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
setFieldValue(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
setFieldValue(LoggerStatus._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
setFieldValue(MasterClientService.createTable_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setFieldValue(MasterClientService.createTable_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
setFieldValue(MasterClientService.deleteTable_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
setFieldValue(MasterClientService.deleteTable_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
setFieldValue(MasterClientService.flushTable_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
setFieldValue(MasterClientService.flushTable_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
setFieldValue(MasterClientService.getMasterStats_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
setFieldValue(MasterClientService.offlineTable_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
setFieldValue(MasterClientService.offlineTable_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
setFieldValue(MasterClientService.onlineTable_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
setFieldValue(MasterClientService.onlineTable_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_result
 
setFieldValue(MasterClientService.removeSystemProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
 
setFieldValue(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
 
setFieldValue(MasterClientService.renameTable_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
setFieldValue(MasterClientService.renameTable_result._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_result
 
setFieldValue(MasterClientService.reportSplitExtent_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
setFieldValue(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
 
setFieldValue(MasterClientService.setSystemProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
 
setFieldValue(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
 
setFieldValue(MasterMonitorInfo._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setFieldValue(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setFieldValue(TabletInfo._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setFieldValue(TabletServerStatus._Fields, Object) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
setFieldValue(AuthInfo._Fields, Object) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
setFieldValue(ThriftSecurityException._Fields, Object) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
setFieldValue(int, Object) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
setFieldValue(ActionStats._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setFieldValue(ActiveScan._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setFieldValue(CompactionStats._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
setFieldValue(ConstraintViolationException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
setFieldValue(int, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
setFieldValue(LogFile._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
setFieldValue(MutationLogger.close_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
setFieldValue(MutationLogger.close_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
setFieldValue(MutationLogger.create_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
setFieldValue(MutationLogger.create_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
setFieldValue(MutationLogger.defineTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setFieldValue(MutationLogger.defineTablet_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
setFieldValue(MutationLogger.getClosedLogs_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
setFieldValue(MutationLogger.getClosedLogs_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
setFieldValue(MutationLogger.log_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setFieldValue(MutationLogger.log_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
setFieldValue(MutationLogger.logManyTablets_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
setFieldValue(MutationLogger.logManyTablets_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
setFieldValue(MutationLogger.minorCompactionFinished_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setFieldValue(MutationLogger.minorCompactionFinished_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
setFieldValue(MutationLogger.minorCompactionStarted_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setFieldValue(MutationLogger.minorCompactionStarted_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
setFieldValue(MutationLogger.remove_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
setFieldValue(MutationLogger.startCopy_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setFieldValue(MutationLogger.startCopy_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
setFieldValue(NoSuchLogIDException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
setFieldValue(int, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
setFieldValue(NoSuchScanIDException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
setFieldValue(int, 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(int, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
setFieldValue(TabletClientService.applyUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
setFieldValue(TabletClientService.bulkImport_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
setFieldValue(TabletClientService.closeMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
 
setFieldValue(int, 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(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
setFieldValue(TabletClientService.continueMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
 
setFieldValue(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
 
setFieldValue(TabletClientService.flush_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setFieldValue(TabletClientService.getActiveScans_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
 
setFieldValue(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
setFieldValue(TabletClientService.loadTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
setFieldValue(TabletClientService.setUpdateTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
setFieldValue(TabletClientService.splitTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
setFieldValue(int, 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(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
setFieldValue(TabletClientService.startMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
 
setFieldValue(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, 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(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
setFieldValue(TabletClientService.useLoggers_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
setFieldValue(TabletMutations._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
setFieldValue(TabletStats._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setFieldValue(TestService.setTimeOffset_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
setFieldValue(TestService.setTimeOffset_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
setFieldValue(int, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
setFieldValue(TooManyFilesException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
setFieldValue(int, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
setFiles(List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_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.tabletserver.thrift.MutationLogger.remove_args
 
setFilesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
setFileType(JobContext, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
setFinished(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setFinishedIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setFqfn(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setFqfn(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setFqfnIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setFqfnIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_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
 
setFullyQualifiedFileName(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setFullyQualifiedFileNameIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setGoalState(MasterGoalState) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setGoalStateIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setHoldTime(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setHoldTimeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setHost(String) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setHostIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
setId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
setId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
setId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setIdleTime(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setIdleTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setIndexInterval(int) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Sets the index interval.
setIndexInterval(Configuration, int) - Static method in class org.apache.accumulo.core.file.map.MyMapFile.Writer
Deprecated. Sets the index interval and stores it in conf
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
 
setInputInfo(JobContext, String, byte[], String, Authorizations) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
setInstance(Configuration) - Static method in class org.apache.accumulo.core.util.CachedConfiguration
 
setInstanceId(String) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
setInstanceIdIsSet(boolean) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
setInterpreter(VisibilityInterpreter) - Static method in class org.apache.accumulo.core.security.VisibilityInterpreterFactory
 
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
Deprecated.  
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.file.map.MyMapFile.Reader
Deprecated.  
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.ColumnFamilySkippingIterator
 
setInterruptFlag(AtomicBoolean) - Method in interface org.apache.accumulo.core.iterators.InterruptibleIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.SequenceFileIterator
Deprecated.  
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iterators.SourceSwitchingIterator
 
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(JobContext, boolean) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
Enable or disable use of the IsolatedScanner.
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
 
setIterator(JobContext, int, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
Specify an Accumulo iterator type to manage the behavior of the underlying table scan this InputFormat's Record Reader will conduct, w/ priority dictating the order in which specified iterators are applied.
setIteratorOption(JobContext, String, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
Specify an option for a named Accumulo iterator, further specifying that iterator's behavior.
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
 
setKeyExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.setUpdateTablet_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
 
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
 
setLeft(BinaryTree<T>) - Method in class org.apache.accumulo.core.util.BinaryTree
 
setLocalityGroups(String, Map<String, Set<Text>>) - Method in class org.apache.accumulo.core.client.admin.TableOperations
Sets a tables locality groups.
setLocalityGroups(String, Map<String, Set<Text>>) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Sets a tables locality groups.
setLocalityGroups(String, Map<String, Set<Text>>) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
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.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
 
setLockFile(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
setLockFileIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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
 
setLogger(String) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
setLoggerIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
setLoggers(List<LoggerStatus>) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setLoggers(Set<String>) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLoggers(Set<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
setLoggersIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setLoggersIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLoggersIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
setLogLevel(JobContext, Level) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
setLogLevel(JobContext, Level) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
setLookups(long) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setLookupsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setMajor(Compacting) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setMajor(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMajorCount(long) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorCountIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorElapsed(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorElapsedIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorFail(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorFailIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setMajorIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMajorNum(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorNumIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorQueueSumDev(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorQueueSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorQueueTime(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorQueueTimeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorSumDev(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMajorSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMapProgress(double) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setMapProgressIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setMasterGoalState(TInfo, AuthInfo, MasterGoalState) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
setMasterGoalState(TInfo, AuthInfo, MasterGoalState) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
setMaxLatency(JobContext, int) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
setMaxMutationBufferSize(JobContext, long) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
setMaxSize(long) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
 
setMaxVersions(JobContext, int) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
Sets the max # of values that may be returned for an individual Accumulo cell.
setMaxWriteThreads(JobContext, int) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
setMemory(int) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Set the total amount of buffer memory, in bytes.
setMillis(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
setMillisIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
setMinor(Compacting) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setMinor(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMinorCount(long) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorCountIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorElapsed(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorElapsedIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorFail(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorFailIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
setMinorIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMinorNum(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorNumIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorQueueSumDev(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorQueueSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorQueueTime(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorQueueTimeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorSumDev(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMinorSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setMockInstance(JobContext, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
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.tabletserver.thrift.MutationLogger.log_args
 
setMutation(TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
setMutation(TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setMutationIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setMutationIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
setMutationIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
setMutations(List<TabletMutations>) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
setMutations(List<TMutation>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
setMutationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
setMutationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
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.LogFile
 
setName(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
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.LogFile
 
setNameIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setNewTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
setNewTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
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
 
setNsli(NoSuchLogIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
setNsli(NoSuchLogIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
setNsli(NoSuchLogIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
setNsli(NoSuchLogIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
setNsli(NoSuchLogIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
setNsli(NoSuchLogIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
setNsliIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
setNsliIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
setNsliIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
setNsliIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
setNsliIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
setNsliIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
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.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.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.master.thrift.TabletInfo
 
setNumEntries(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setNumEntriesIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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(Scanner, String, int) - Static method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
setNumSubBins(JobContext, int) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
Sets the number of random sub-bins per range
setNumSubBins(JobContext, int) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
Sets the number of random sub-bins per range
setOldTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
setOldTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
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
 
setOpIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setOptions(ScannerOptions, ScannerOptions) - Static method in class org.apache.accumulo.core.client.impl.ScannerOptions
 
setOsLoad(double) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setOsLoadIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
setOutputInfo(JobContext, String, byte[], boolean, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
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.authenticateUser_args
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
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.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.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.revokeSystemPermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
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
 
setPrevEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setPriority(int) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setPriorityIsSet(boolean) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
setProgressable(Progressable) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Set the progressable object in order to report progress.
setProperty(String, String) - Method in class org.apache.accumulo.core.client.admin.InstanceOperations
Sets an instance property in zookeeper.
setProperty(String, String, String) - Method in class org.apache.accumulo.core.client.admin.TableOperations
Sets a property on a table
setProperty(String, String, String) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
Sets a property on a table
setProperty(String, String, String) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
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.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.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.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
 
setQueueSumDev(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
setQueueSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
setQueueTime(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueTime(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
setQueueTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
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.mock.MockScanner
 
setRange(Range) - Method in interface org.apache.accumulo.core.client.Scanner
 
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 scanning over 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(JobContext, Collection<Range>) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
setRanges(Collection<Range>) - Method in class org.apache.accumulo.core.client.mock.MockBatchScanner
 
setRecovery(List<RecoveryStatus>) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
setRecoveryIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
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
 
setReduceProgress(double) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setReduceProgressIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
setRegex(JobContext, AccumuloInputFormat.RegexType, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
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(byte[]) - 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
 
setRowRegex(String) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Set a row regular expression that filters non matching entries server side.
setRowRegex(String) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
setRowRegex(String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Set a row regular expression that filters non matching entries server side.
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
 
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.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.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
 
setScanIteratorOption(String, String, String) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Sets options for server side scan iterators.
setScanIteratorOption(String, String, String) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
setScanIteratorOption(String, String, String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Sets options for server side scan iterators.
setScanIterators(int, String, String) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Sets server side scan iterators.
setScanIterators(int, String, String) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
setScanIterators(int, String, String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Sets server side scan iterators.
setScanIterators(Shell, Scanner) - Method in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
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.changeAuthorizations_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_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.changeAuthorizations_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
setSeq(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setSeq(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setSeq(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setSeq(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setSeq(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
setSeqIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setSeqIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setSeqIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setSeqIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setSeqIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
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
 
setSimulationMode(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
setSort(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setSortIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
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
 
setSplit(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitCreationTime(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitCreationTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitElapsed(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setSplitElapsedIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setSplitFail(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setSplitFailIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setSplitFile(JobContext, 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(JobContext, 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
 
setSplitIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitNum(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setSplitNumIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setSplitPoint(byte[]) - 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
 
setSplitPoints(List<byte[]>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setSplitPointsIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setSplitSumDev(double) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setSplitSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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.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.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.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
 
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
 
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
 
setStats(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
setStatsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
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.master.thrift.MasterClientService.reportTabletStatus_args
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setStatusMajor(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setStatusMajorIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setStatusMinor(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setStatusMinorIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setStatusSplit(int) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
setStatusSplitIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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.authenticateUser_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
 
setSuccess(List<byte[]>) - 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.hasSystemPermission_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
 
setSuccess(Set<String>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
setSuccess(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSuccess(MasterMonitorInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
setSuccess(LogFile) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
setSuccess(List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
setSuccess(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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(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<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(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.authenticateUser_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.getRootTabletLocation_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.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.listUsers_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.getMasterStats_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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.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
 
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, AuthInfo, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
setSystemProperty(TInfo, AuthInfo, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
setSystemTimestamp(long) - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
setTable(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
setTableId(String) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.getTabletStats_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.getTabletStats_args
 
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.finishBulkImport_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.prepareBulkImport_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.master.thrift.MasterClientService.createTable_args
 
setTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
setTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
setTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
setTableName(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.prepareBulkImport_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.createTable_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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
 
setTableProperties(CommandLine, Shell, String, int, Map<String, String>, String, String) - Method in class org.apache.accumulo.core.util.shell.Shell.SetIterCommand
 
setTableProperties(CommandLine, Shell, String, int, Map<String, String>, String, String) - Method in class org.apache.accumulo.core.util.shell.Shell.SetScanIterCommand
 
setTableProperty(TInfo, AuthInfo, String, String, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
setTableProperty(TInfo, AuthInfo, String, String, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
setTables(Set<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setTablesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
setTablet(TKeyExtent) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setTablet(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setTabletID(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
setTabletIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
setTabletIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
setTabletIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_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
 
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
 
setTid(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setTid(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setTid(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setTid(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setTimeOffset(AuthInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
setTimeOffset(AuthInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TestService.Iface
 
setTimeOut(int) - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
When failure occurs, the scanner automatically retries.
setTimeOut(int) - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
setTimeOut(int) - Method in class org.apache.accumulo.core.client.mock.MockScanner
 
setTimeOut(int) - Method in interface org.apache.accumulo.core.client.Scanner
When failure occurs, the scanner automatically retries.
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
 
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.changeAuthorizations_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.close_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_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.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.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.flush_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.loadTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_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.changeAuthorizations_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.close_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_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.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.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.flush_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.loadTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_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
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.hasTablePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.hasTablePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
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
 
setTserverSession(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
setTserverSessionIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
setTt(TimeType) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setTtIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
setType(TableOperationExceptionType) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
setType(ScanType) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setTypeIsSet(boolean) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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
 
setUpdateID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
setUpdateID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
setUpdateID(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
setUpdateIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
setUpdateIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
setUpdateIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
setUpdateTablet(TInfo, long, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
setUpdateTablet(TInfo, long, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
setUpIterator(int, String, String, BatchScanner) - Method in class org.apache.accumulo.core.util.shell.Shell.EGrepCommand
 
setUpIterator(int, String, String, BatchScanner) - Method in class org.apache.accumulo.core.util.shell.Shell.GrepCommand
 
setupRegex(String, int) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Must call this method to initialize regular expresions on a scanner.
setupRegex(String, int) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
setupRegex(String, int) - Method in interface org.apache.accumulo.core.client.ScannerBase
Call this method to initialize regular expressions on a scanner.
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setUser(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setUser(String) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
setUser(String) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
setUser(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
setUserIsSet(boolean) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
setValue(Value) - Method in class org.apache.accumulo.core.data.KeyValue
 
setValue(byte[]) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
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.setSystemProperty_args
 
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
 
setValueRegex(String) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
Set a value regular expression that filters non matching entries server side.
setValueRegex(String) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchDeleter
 
setValueRegex(String) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
 
setValueRegex(String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Set a value regular expression that filters non matching entries server side.
setValues(List<byte[]>) - 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
 
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
 
setZooKeeperInstance(JobContext, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
 
setZooKeeperInstance(JobContext, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
setZooKeeperInstance(JobContext, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
 
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.AboutCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.AboutCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.AboutCommand
 
Shell.AddSplitsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.AddSplitsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.AddSplitsCommand
 
Shell.AuthenticateCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.AuthenticateCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.AuthenticateCommand
 
Shell.ByeCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ByeCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ByeCommand
 
Shell.ClasspathCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ClasspathCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ClasspathCommand
 
Shell.ClearCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ClearCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ClearCommand
 
Shell.ClsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ClsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ClsCommand
 
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.CommandFactory - Class in org.apache.accumulo.core.util.shell
Command Factory is a class that holds the command table, which is a mapping from a string representing the command to a class.
Shell.CommandFactory() - Constructor for class org.apache.accumulo.core.util.shell.Shell.CommandFactory
 
Shell.CommandFactory.CodeType - Enum in org.apache.accumulo.core.util.shell
 
Shell.CompactCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.CompactCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.CompactCommand
 
Shell.ConfigCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ConfigCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ConfigCommand
 
Shell.CreateTableCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.CreateTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.CreateTableCommand
 
Shell.CreateUserCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.CreateUserCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.CreateUserCommand
 
Shell.DebugCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DebugCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DebugCommand
 
Shell.DeleteCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DeleteCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DeleteCommand
 
Shell.DeleteIterCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DeleteIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DeleteIterCommand
 
Shell.DeleteManyCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DeleteManyCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DeleteManyCommand
 
Shell.DeleteScanIterCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DeleteScanIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DeleteScanIterCommand
 
Shell.DeleteTableCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DeleteTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DeleteTableCommand
 
Shell.DeleteUserCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DeleteUserCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DeleteUserCommand
 
Shell.DropTableCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DropTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DropTableCommand
 
Shell.DropUserCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.DropUserCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.DropUserCommand
 
Shell.EGrepCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.EGrepCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.EGrepCommand
 
Shell.ExecfileCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ExecfileCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ExecfileCommand
 
Shell.ExitCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ExitCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ExitCommand
 
Shell.FlushCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.FlushCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.FlushCommand
 
Shell.FormatterCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.FormatterCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.FormatterCommand
 
Shell.GetAuthsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.GetAuthsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.GetAuthsCommand
 
Shell.GetGroupsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.GetGroupsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.GetGroupsCommand
 
Shell.GetSplitsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.GetSplitsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.GetSplitsCommand
 
Shell.GrantCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.GrantCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.GrantCommand
 
Shell.GrepCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.GrepCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.GrepCommand
 
Shell.HelpCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.HelpCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.HelpCommand
 
Shell.HiddenCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.HiddenCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.HiddenCommand
 
Shell.ImportDirectoryCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ImportDirectoryCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ImportDirectoryCommand
 
Shell.InfoCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.InfoCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.InfoCommand
 
Shell.InsertCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.InsertCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.InsertCommand
 
Shell.ListScansCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ListScansCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ListScansCommand
 
Shell.MasterStateCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.MasterStateCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.MasterStateCommand
 
Shell.OfflineCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.OfflineCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.OfflineCommand
 
Shell.OnlineCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.OnlineCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.OnlineCommand
 
Shell.PasswdCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.PasswdCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.PasswdCommand
 
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
 
Shell.QuestionCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.QuestionCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.QuestionCommand
 
Shell.QuitCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.QuitCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.QuitCommand
 
Shell.RenameTableCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.RenameTableCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.RenameTableCommand
 
Shell.RevokeCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.RevokeCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.RevokeCommand
 
Shell.ScanCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.ScanCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
Shell.SelectCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.SelectCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.SelectCommand
 
Shell.SelectrowCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.SelectrowCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.SelectrowCommand
 
Shell.SetAuthsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.SetAuthsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.SetAuthsCommand
 
Shell.SetGroupsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.SetGroupsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.SetGroupsCommand
 
Shell.SetIterCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.SetIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.SetIterCommand
 
Shell.SetScanIterCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.SetScanIterCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.SetScanIterCommand
 
Shell.SystemPermissionsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.SystemPermissionsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.SystemPermissionsCommand
 
Shell.TableCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.TableCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.TableCommand
 
Shell.TablePermissionsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.TablePermissionsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.TablePermissionsCommand
 
Shell.TablesCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.TablesCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.TablesCommand
 
Shell.TraceCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.TraceCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.TraceCommand
 
Shell.UserCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.UserCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.UserCommand
 
Shell.UserPermissionsCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.UserPermissionsCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.UserPermissionsCommand
 
Shell.UsersCommand - Class in org.apache.accumulo.core.util.shell
 
Shell.UsersCommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.UsersCommand
 
Shell.WhoAmICommand - Class in org.apache.accumulo.core.util.shell
 
Shell.WhoAmICommand() - Constructor for class org.apache.accumulo.core.util.shell.Shell.WhoAmICommand
 
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
 
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
 
shouldPreserveInput() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter.SegmentDescriptor
Deprecated.  
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, AuthInfo, boolean) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
shutdown(TInfo, AuthInfo, boolean) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
 
shutdownTabletServer(TInfo, AuthInfo, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
 
shutdownTabletServer(TInfo, AuthInfo, String) - 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
SiteConfiguration - Class in org.apache.accumulo.core.conf
 
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.security.Authorizations
 
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
SkippingIterator - Class in org.apache.accumulo.core.iterators
 
SkippingIterator() - Constructor for class org.apache.accumulo.core.iterators.SkippingIterator
 
sleep(long) - Static method in class org.apache.accumulo.core.util.UtilWaitThread
 
sort(Path[], Path, boolean) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Perform a file sort from a set of input files into an output file.
sort(Path, Path) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. The backwards compatible interface to sort.
sort - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
sortAndIterate(Path[], Path, boolean) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Perform a file sort from a set of input files and return an iterator.
sortByStart(Collection<RemoteSpan>) - Static method in class org.apache.accumulo.core.trace.TraceDump
 
sortedColFams - Variable in class org.apache.accumulo.core.iterators.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
SortedMapIterator(SortedMap<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.SortedMapIterator
 
SourceSwitchingIterator - Class in org.apache.accumulo.core.iterators
 
SourceSwitchingIterator(SourceSwitchingIterator.DataSource, boolean) - Constructor for class org.apache.accumulo.core.iterators.SourceSwitchingIterator
 
SourceSwitchingIterator(SourceSwitchingIterator.DataSource) - Constructor for class org.apache.accumulo.core.iterators.SourceSwitchingIterator
 
SourceSwitchingIterator.DataSource - Interface in org.apache.accumulo.core.iterators
 
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 - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
split - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
splitCreationTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
splitElapsed - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
splitFail - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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
 
splitNum - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
splitPoint - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
splitPoints - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
splitRangeByTablets(String, Range, int) - Method in class org.apache.accumulo.core.client.admin.TableOperations
 
splitRangeByTablets(String, Range, int) - Method in class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
splitRangeByTablets(String, Range, int) - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
splitSumDev - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
splitTablet(TInfo, AuthInfo, TKeyExtent, byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
splitTablet(TInfo, AuthInfo, TKeyExtent, byte[]) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
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.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
 
start - Variable in class org.apache.accumulo.core.data.thrift.TRange
 
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_TIME - Static variable in class org.apache.accumulo.core.trace.TraceDump
 
startCopy(TInfo, AuthInfo, String, String, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Client
 
startCopy(TInfo, AuthInfo, String, String, boolean) - Method in interface org.apache.accumulo.core.tabletserver.thrift.MutationLogger.Iface
 
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, AuthInfo, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<byte[]>, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
startMultiScan(TInfo, AuthInfo, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<byte[]>, 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
 
startScan(TInfo, AuthInfo, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<byte[]>, boolean, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
startScan(TInfo, AuthInfo, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<byte[]>, boolean, boolean) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
startUpdate(TInfo, AuthInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
startUpdate(TInfo, AuthInfo) - 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
 
stats - Variable in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
status - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
status - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
statusMajor - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
statusMinor - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
statusSplit - Variable in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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
 
StopWatch<K extends java.lang.Enum<K>> - Class in org.apache.accumulo.core.util
 
StopWatch(Class<K>) - Constructor for class org.apache.accumulo.core.util.StopWatch
 
STRING - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
String overhead
StringMax - Class in org.apache.accumulo.core.iterators.aggregation
 
StringMax() - Constructor for class org.apache.accumulo.core.iterators.aggregation.StringMax
 
StringMin - Class in org.apache.accumulo.core.iterators.aggregation
 
StringMin() - Constructor for class org.apache.accumulo.core.iterators.aggregation.StringMin
 
StringSummation - Class in org.apache.accumulo.core.iterators.aggregation
 
StringSummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.StringSummation
 
stringToBytes(String) - Static method in class org.apache.accumulo.core.data.Value
Converts a string to a byte array in a consistent manner.
stringTopKey(SortedKeyValueIterator<Key, Value>) - Static method in class org.apache.accumulo.core.iterators.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.authenticateUser_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.getRootTabletLocation_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.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.listUsers_result
 
success - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
success - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
success - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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.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
 
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.LargeRowFilter
 
switchNow() - Method in class org.apache.accumulo.core.iterators.SourceSwitchingIterator
 
sync(long) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Seek to the next sync mark past a given position.
sync() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated. create a sync point
SYNC_INTERVAL - Static variable in class org.apache.accumulo.core.file.map.MySequenceFile
Deprecated. The number of bytes between sync points.
syncSeen() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns true iff the previous call to next passed a sync mark.
sysPerm - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
SystemPermission - Enum in org.apache.accumulo.core.security
 
SystemScanIterator - Class in org.apache.accumulo.core.iterators
 
SystemScanIterator(SortedKeyValueIterator<Key, Value>, Authorizations, byte[], HashSet<Column>) - Constructor for class org.apache.accumulo.core.iterators.SystemScanIterator
 

T

table - Variable in class org.apache.accumulo.core.client.mock.MockScannerBase
 
table - Variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
TABLE_TABLET_LOCATION - Static variable in class org.apache.accumulo.core.Constants
 
TableConfiguration - Class in org.apache.accumulo.core.conf
 
TableConfiguration(String, String, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.conf.TableConfiguration
 
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 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.getTabletStats_args
 
tableIdMap() - Method in class 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.admin.TableOperationsImpl
Get a mapping of table name to internal table id.
tableIdMap() - Method in class org.apache.accumulo.core.client.mock.MockTableOperations
 
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) - 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.client.impl.thrift.ClientService.finishBulkImport_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.prepareBulkImport_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.createTable_args
 
tableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
tableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
tableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
tableName - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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
 
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
 
tableOfMetadataRow(Text) - Static method in class org.apache.accumulo.core.data.KeyExtent
 
TableOperation - Enum in org.apache.accumulo.core.client.impl.thrift
 
TableOperationExceptionType - Enum in org.apache.accumulo.core.client.impl.thrift
 
TableOperations - Class in org.apache.accumulo.core.client.admin
Provides a class for administering tables
TableOperations() - Constructor for class org.apache.accumulo.core.client.admin.TableOperations
 
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
 
TableOperationsImpl - Class in org.apache.accumulo.core.client.admin
Provides a class for administering tables
TableOperationsImpl(Instance, AuthInfo) - Constructor for class org.apache.accumulo.core.client.admin.TableOperationsImpl
 
TablePermission - Enum in org.apache.accumulo.core.security
 
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.tabletserver.thrift.TabletClientService.flush_args
 
tablet - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
tablet - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_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
 
TabletClientService - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService
 
TabletClientService.applyUpdate_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.applyUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
TabletClientService.applyUpdate_args(TInfo, long, TMutation) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
TabletClientService.applyUpdate_args(TabletClientService.applyUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
Performs a deep copy on other.
TabletClientService.applyUpdate_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_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, AuthInfo, Map<TKeyExtent, Map<String, MapFileInfo>>) - 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.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.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.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.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, AuthInfo, String, Set<String>) - 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.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, AuthInfo) - 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, AuthInfo) - 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, AuthInfo) - 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, AuthInfo, 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, AuthInfo, 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.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, AuthInfo, 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 - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.Processor(TabletClientService.Iface) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor
 
TabletClientService.setUpdateTablet_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.setUpdateTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
TabletClientService.setUpdateTablet_args(TInfo, long, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
TabletClientService.setUpdateTablet_args(TabletClientService.setUpdateTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
Performs a deep copy on other.
TabletClientService.setUpdateTablet_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, AuthInfo, TKeyExtent, byte[]) - 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.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, AuthInfo, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<byte[]>, 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, AuthInfo, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<byte[]>, boolean, boolean) - 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, AuthInfo) - 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, AuthInfo, 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, AuthInfo, 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.
TabletClientService.useLoggers_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletClientService.useLoggers_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
TabletClientService.useLoggers_args(TInfo, AuthInfo, Set<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
TabletClientService.useLoggers_args(TabletClientService.useLoggers_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
Performs a deep copy on other.
TabletClientService.useLoggers_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.
tabletId - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
tabletID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
TabletInfo - Class in org.apache.accumulo.core.master.thrift
 
TabletInfo() - Constructor for class org.apache.accumulo.core.master.thrift.TabletInfo
 
TabletInfo(int, double, int, long, double, double, double, int, int, double, int, double, int, int, double, int, long, double, double, double, int, long) - Constructor for class org.apache.accumulo.core.master.thrift.TabletInfo
 
TabletInfo(TabletInfo) - Constructor for class org.apache.accumulo.core.master.thrift.TabletInfo
Performs a deep copy on other.
TabletInfo._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.
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) - Constructor for class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
 
TabletLocator.TabletServerMutations - Class in org.apache.accumulo.core.client.impl
 
TabletLocator.TabletServerMutations() - 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) - Constructor for class org.apache.accumulo.core.client.impl.TabletLocatorImpl
 
TabletLocatorImpl.TabletLocationObtainer - Interface in org.apache.accumulo.core.client.impl
 
TabletMutations - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletMutations() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
TabletMutations(int, long, List<TMutation>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
TabletMutations(TabletMutations) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
Performs a deep copy on other.
TabletMutations._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.
TabletOperations - Class in org.apache.accumulo.core.util
 
TabletOperations() - Constructor for class org.apache.accumulo.core.util.TabletOperations
 
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, AuthInfo, String, Authorizations, int, long, long, int) - Constructor for class org.apache.accumulo.core.client.impl.TabletServerBatchDeleter
 
TabletServerBatchReader - Class in org.apache.accumulo.core.client.impl
 
TabletServerBatchReader(Instance, AuthInfo, String, Authorizations, int) - Constructor for class org.apache.accumulo.core.client.impl.TabletServerBatchReader
 
TabletServerBatchReaderIterator - Class in org.apache.accumulo.core.client.impl
 
TabletServerBatchReaderIterator(Instance, AuthInfo, String, Authorizations, ArrayList<Range>, int, ExecutorService, ScannerOptions) - 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, AuthInfo, long, long, int) - 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, Set<String>) - 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
 
tblPerm - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
TColumn - Class in org.apache.accumulo.core.data.thrift
 
TColumn() - Constructor for class org.apache.accumulo.core.data.thrift.TColumn
 
TColumn(byte[], byte[], byte[]) - 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.
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.
TCVST - Static variable in class org.apache.accumulo.core.client.impl.Translator
 
term - Variable in class org.apache.accumulo.core.iterators.IntersectingIterator.TermSource
 
term - Variable in class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
TestService - Class in org.apache.accumulo.core.tabletserver.thrift
 
TestService() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService
 
TestService.Client - Class in org.apache.accumulo.core.tabletserver.thrift
 
TestService.Client(TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
TestService.Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.Client
 
TestService.Client.Factory - Class in org.apache.accumulo.core.tabletserver.thrift
 
TestService.Client.Factory() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.Client.Factory
 
TestService.Iface - Interface in org.apache.accumulo.core.tabletserver.thrift
 
TestService.Processor - Class in org.apache.accumulo.core.tabletserver.thrift
 
TestService.Processor(TestService.Iface) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.Processor
 
TestService.Processor.ProcessFunction - Interface in org.apache.accumulo.core.tabletserver.thrift
 
TestService.setTimeOffset_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TestService.setTimeOffset_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
TestService.setTimeOffset_args(AuthInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
TestService.setTimeOffset_args(TestService.setTimeOffset_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
Performs a deep copy on other.
TestService.setTimeOffset_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.
TestService.setTimeOffset_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TestService.setTimeOffset_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
TestService.setTimeOffset_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
TestService.setTimeOffset_result(TestService.setTimeOffset_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
Performs a deep copy on other.
TestService.setTimeOffset_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.
testTable - Static variable in class org.apache.accumulo.core.util.shell.Shell.CreateTableCommand
 
TextUtil - Class in org.apache.accumulo.core.util
 
TextUtil() - Constructor for class org.apache.accumulo.core.util.TextUtil
 
TFile - Class in org.apache.accumulo.core.file.rfile.bcfile
A TFile is a container of key-value pairs.
TFile.Reader - Class in org.apache.accumulo.core.file.rfile.bcfile
TFile Reader.
TFile.Reader(FSDataInputStream, long, Configuration) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader
Constructor
TFile.Reader.Scanner - Class in org.apache.accumulo.core.file.rfile.bcfile
The TFile Scanner.
TFile.Reader.Scanner(TFile.Reader, long, long) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Constructor
TFile.Reader.Scanner(TFile.Reader, RawComparable, RawComparable) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Constructor
TFile.Reader.Scanner.Entry - Class in org.apache.accumulo.core.file.rfile.bcfile
Entry to a <Key, Value> pair.
TFile.Reader.Scanner.Entry() - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
 
TFile.Writer - Class in org.apache.accumulo.core.file.rfile.bcfile
TFile Writer.
TFile.Writer(FSDataOutputStream, int, String, String, Configuration) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.TFile.Writer
Constructor
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(AuthInfo, 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.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.security.thrift
 
ThriftSecurityException() - Constructor for exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
ThriftSecurityException(String, SecurityErrorCode) - Constructor for exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
ThriftSecurityException(ThriftSecurityException) - Constructor for exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
Performs a deep copy on other.
ThriftSecurityException._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.
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.
ThriftTransportPool - Class in org.apache.accumulo.core.client.impl
 
ThriftUtil - Class in org.apache.accumulo.core.util
 
ThriftUtil() - Constructor for class org.apache.accumulo.core.util.ThriftUtil
 
tid - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
tid - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
tid - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
tid - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
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
 
timestampOpt - Variable in class org.apache.accumulo.core.util.shell.Shell.ScanCommand
 
TimeType - Enum in org.apache.accumulo.core.client.admin
The type of ordering to use for the table's entries (default is MILLIS)
TimeType - Enum in org.apache.accumulo.core.master.thrift
 
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.changeAuthorizations_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_args
 
tinfo - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
tinfo - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.close_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_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.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.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.flush_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.loadTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
TKET - Static variable in class org.apache.accumulo.core.client.impl.Translator
 
TKey - Class in org.apache.accumulo.core.data.thrift
 
TKey() - Constructor for class org.apache.accumulo.core.data.thrift.TKey
 
TKey(byte[], byte[], byte[], byte[], 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(byte[], byte[], byte[]) - 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, byte[]) - 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
 
TMutation - Class in org.apache.accumulo.core.data.thrift
 
TMutation() - Constructor for class org.apache.accumulo.core.data.thrift.TMutation
 
TMutation(byte[], byte[], List<byte[]>, 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
 
toBytes() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
toColumn() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
toDataRange() - Method in class org.apache.accumulo.core.data.KeyExtent
 
Token - Class in org.apache.accumulo.core.util.shell
 
toList() - Method in class org.apache.accumulo.core.util.ByteArraySet
 
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.finishBulkImport_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.hasTablePermission_result
 
tope - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_result
 
tope - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
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.client.impl.TabletLocator.TabletLocation
 
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.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.changePassword_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args
 
toString() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.KeyValue
 
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.TColumn
 
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.map.MySequenceFile.Metadata
Deprecated.  
toString() - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Reader
Deprecated. Returns the name of the file.
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.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.LoggerStatus
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args
 
toString() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo
 
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.security.Authorizations
 
toString() - Method in class org.apache.accumulo.core.security.ColumnVisibility
 
toString() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
toString() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
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.ActiveScan
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_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.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.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.flush_args
 
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.loadTablet_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
toString(InetSocketAddress) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
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() - Method in class org.apache.accumulo.core.util.MetadataTable.DataFileValue
 
toString() - Method in class org.apache.accumulo.core.util.Pair
 
toString() - Method in class org.apache.accumulo.core.util.ServerServices
 
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.zookeeper.ZooLock.LockID
 
toStringNoTime() - Method in class org.apache.accumulo.core.data.Key
 
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
 
toThrift() - Method in class org.apache.accumulo.core.data.Range
 
TRACE_TABLE - Static variable in class org.apache.accumulo.core.trace.TraceDump
 
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
 
transition(byte) - Method in class org.apache.accumulo.core.security.ByteArrayTrie
 
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(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.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
 
transportFactory() - 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
Trie<VT> - Class in org.apache.accumulo.core.client.impl
 
Trie(int) - Constructor for class org.apache.accumulo.core.client.impl.Trie
 
TRT - Static variable in class org.apache.accumulo.core.client.impl.Translator
 
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
 
tryLock(ZooLock.LockWatcher, byte[]) - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
tryToCancelAsyncLockOrUnlock() - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
tryToGetFirstAndLastRows(Set<String>) - Static method in class org.apache.accumulo.core.file.FileUtil
 
TSERV_MINC_MAXCONCURRENT_NUMWAITING_MULTIPLIER - Static variable in class org.apache.accumulo.core.Constants
 
tServerInfo - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
tserverSession - Variable in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
tt - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
TTimeoutTransport - Class in org.apache.accumulo.core.util
 
TTimeoutTransport() - Constructor for class org.apache.accumulo.core.util.TTimeoutTransport
 
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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
type - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 

U

unassignedTablets - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
uncompressedValSerializer - Variable in class org.apache.accumulo.core.file.map.MySequenceFile.Writer
Deprecated.  
unloadTablet(TInfo, AuthInfo, String, TKeyExtent, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
unloadTablet(TInfo, AuthInfo, String, TKeyExtent, boolean) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
unlock() - Method in class org.apache.accumulo.core.zookeeper.ZooLock
 
unnamedOptionDescriptions - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
unsetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetAggs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_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.client.impl.thrift.ClientService.createUser_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
 
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
 
unsetClassName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
unsetClient() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetCode() - Method in exception org.apache.accumulo.core.security.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
 
unsetConstrainClass() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
 
unsetCopyProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
unsetCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
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.changeAuthorizations_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.flush_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.splitTablet_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
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
unsetCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetCve() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
unsetData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
unsetDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetDescription() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
unsetDir() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
unsetDisableGC() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
unsetElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
 
unsetEntries() - Method in class org.apache.accumulo.core.data.thrift.TMutation
 
unsetErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetErrPercent() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_args
 
unsetEstimatedSize() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
 
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.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
 
unsetFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_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
 
unsetFqfn() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
unsetFqfn() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
unsetFullScans() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
 
unsetFullyQualifiedFileName() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
unsetGoalState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetHoldTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetHost() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
unsetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
unsetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
unsetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
unsetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
unsetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
unsetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
unsetId() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
unsetIdleTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
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
 
unsetInstanceId() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
unsetInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetIsolated() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
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.setUpdateTablet_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
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_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
 
unsetLockFile() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
unsetLogger() - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
unsetLoggers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetLoggers() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetLoggers() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_args
 
unsetLookups() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
unsetMajor() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetMajor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetMajorCount() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMajorElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMajorFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMajorNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMajorQueueSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMajorQueueTime() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMajorSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMapProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
unsetMillis() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
unsetMinor() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetMinor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetMinorCount() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMinorElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMinorFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMinorNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMinorQueueSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMinorQueueTime() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetMinorSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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.tabletserver.thrift.MutationLogger.log_args
 
unsetMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_args
 
unsetMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
unsetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
unsetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
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.LogFile
 
unsetName() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
unsetNewTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
unsetNewTablets() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
 
unsetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
unsetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
unsetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
unsetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
unsetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
unsetNsli() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
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.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.master.thrift.TabletInfo
 
unsetNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetOldTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_args
 
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
 
unsetOsLoad() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
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.authenticateUser_args
 
unsetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
unsetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
unsetPassword() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
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.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
 
unsetPriority() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
 
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.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
 
unsetQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
unsetQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
unsetRange() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
 
unsetRecovery() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetRecs() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetRecsInMemory() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetReduceProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
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.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
 
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.changeAuthorizations_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
unsetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_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.prepareBulkImport_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.MasterClientService.createTable_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_result
 
unsetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.create_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
unsetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
unsetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
unsetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
unsetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
unsetSeq() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
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
 
unsetSort() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
unsetSplit() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
 
unsetSplit() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetSplitElapsed() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetSplitFail() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetSplitNum() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
unsetSplitPoints() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
unsetSplitSumDev() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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.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
 
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
 
unsetStats() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
unsetStatus() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
unsetStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetStatusMajor() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetStatusMinor() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
unsetStatusSplit() - Method in class org.apache.accumulo.core.master.thrift.TabletInfo
 
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.authenticateUser_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.getRootTabletLocation_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.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.listUsers_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_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.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.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.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
 
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 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.getTabletStats_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.finishBulkImport_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.prepareBulkImport_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.createTable_args
 
unsetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
unsetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
unsetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_args
 
unsetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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
 
unsetTables() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
unsetTablet() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
 
unsetTablet() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
unsetTabletID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
unsetTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
unsetTabletServer() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
 
unsetTblPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
unsetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
unsetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
unsetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
unsetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
unsetTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TKey
 
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.changeAuthorizations_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.listUsers_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_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.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.tabletserver.thrift.MutationLogger.close_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdate_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.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.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.flush_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.loadTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.useLoggers_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
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.hasTablePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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.MasterClientService.createTable_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_result
 
unsetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
 
unsetTServerInfo() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
 
unsetTserverSession() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
unsetTt() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
unsetType() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.applyUpdate_args
 
unsetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
unsetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
unsetUser() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
unsetUser() - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
unsetUser() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
unsetUser() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
unsetValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
 
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
 
update(Mutation) - Method in class org.apache.accumulo.core.client.impl.Writer
 
update(TInfo, AuthInfo, TKeyExtent, TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
update(TInfo, AuthInfo, TKeyExtent, TMutation) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
updateBinningStats(int, long, Map<String, TabletLocator.TabletServerMutations>) - 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>, List<TKeyExtent>) - 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.applyUpdate_args
 
updateID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
updateID - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_args
 
upperBound(byte[]) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Move the cursor to the first entry whose key is strictly greater than the input key.
upperBound(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner
Move the cursor to the first entry whose key is strictly greater than the input key.
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() - Method in class org.apache.accumulo.core.util.shell.Shell.AddSplitsCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.AuthenticateCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.Command
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.CreateTableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.CreateUserCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.DebugCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.DeleteTableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.DropUserCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.EGrepCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.GrantCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.GrepCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.HelpCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.ImportDirectoryCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.InsertCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.MasterStateCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.RenameTableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.RevokeCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.SelectCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.SelectrowCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.SetGroupsCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.TableCommand
 
usage() - Method in class org.apache.accumulo.core.util.shell.Shell.UserCommand
 
useLoggers(TInfo, AuthInfo, Set<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
useLoggers(TInfo, AuthInfo, Set<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
 
user - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
 
user - Variable in class org.apache.accumulo.core.security.thrift.AuthInfo
 
user - Variable in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
user - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
username - Variable in class org.apache.accumulo.core.trace.InstanceUserPassword
 
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
 

V

VALID_TABLE_NAME_REGEX - Static variable in class org.apache.accumulo.core.Constants
 
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.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.changePassword_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args
 
validate() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
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.TColumn
 
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() - 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.LoggerStatus
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args
 
validate() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo
 
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.AuthInfo
 
validate() - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_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.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.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.flush_args
 
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.loadTablet_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
validateEntries(String, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.util.MetadataTable
 
validateOptions(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.AgeOffFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.ColumnAgeOffFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.NoLabelFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.filter.RegExFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.FilteringIterator
 
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.LargeRowFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.NoLabelIterator
 
validateOptions(Map<String, String>) - Method in interface org.apache.accumulo.core.iterators.OptionDescriber
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.RegExIterator
 
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.VersioningIterator
 
value - Variable in class org.apache.accumulo.core.data.KeyValue
 
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(byte[], boolean) - Constructor for class org.apache.accumulo.core.data.Value
 
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.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_ENCODING - Static variable in class org.apache.accumulo.core.Constants
 
VALUE_REGEX - Static variable in class org.apache.accumulo.core.iterators.filter.RegExFilter
 
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.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.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.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.changePassword_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.changePassword_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.createUser_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.createUser_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.dropUser_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.dropUser_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.finishBulkImport_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.finishBulkImport_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.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.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.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.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.listUsers_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.listUsers_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.prepareBulkImport_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.prepareBulkImport_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.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.ThriftTableOperationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat.RegexType
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.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.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.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.map.MySequenceFile.CompressionType
Deprecated. 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.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.LoggerStatus._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.createTable_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.createTable_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.deleteTable_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.deleteTable_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.flushTable_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.flushTable_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.offlineTable_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.offlineTable_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.onlineTable_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.onlineTable_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.renameTable_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.renameTable_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.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.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.TabletInfo._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.master.thrift.TimeType
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.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.AuthInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.thrift.SecurityErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.thrift.ThriftSecurityException._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.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.CompactionStats._Fields
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.LogFile._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_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.MutationLogger.close_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.MutationLogger.create_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.MutationLogger.create_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.MutationLogger.defineTablet_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.MutationLogger.defineTablet_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.MutationLogger.getClosedLogs_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.MutationLogger.getClosedLogs_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.MutationLogger.log_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.MutationLogger.log_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.MutationLogger.logManyTablets_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.MutationLogger.logManyTablets_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionStarted_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.MutationLogger.minorCompactionStarted_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.MutationLogger.remove_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.MutationLogger.startCopy_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.MutationLogger.startCopy_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.NoSuchLogIDException._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.applyUpdate_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.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.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.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.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.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.setUpdateTablet_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.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.TabletClientService.useLoggers_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.TabletMutations._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.TestService.setTimeOffset_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.TestService.setTimeOffset_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.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.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.Shell.CommandFactory.CodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.zookeeper.ZooLock.LockLossReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.zookeeper.ZooUtil.NodeExistsPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.zookeeper.ZooUtil.NodeMissingPolicy
Returns the enum constant of this type with the specified name.
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.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.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.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.changePassword_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.changePassword_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.createUser_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.createUser_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.dropUser_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.dropUser_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.finishBulkImport_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.finishBulkImport_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.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.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.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.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.listUsers_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.listUsers_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.prepareBulkImport_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.prepareBulkImport_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.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.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.mapreduce.AccumuloInputFormat.RegexType
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.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.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.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.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.map.MySequenceFile.CompressionType
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.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.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.LoggerStatus._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.createTable_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.createTable_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.deleteTable_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.deleteTable_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.flushTable_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.flushTable_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.offlineTable_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.offlineTable_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.onlineTable_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.onlineTable_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.renameTable_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.renameTable_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.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.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.TabletInfo._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.master.thrift.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.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.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.AuthInfo._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.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.security.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.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.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.CompactionStats._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.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.LogFile._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.MutationLogger.close_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.MutationLogger.close_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.MutationLogger.create_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.MutationLogger.create_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.MutationLogger.defineTablet_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.MutationLogger.defineTablet_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.MutationLogger.getClosedLogs_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.MutationLogger.getClosedLogs_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.MutationLogger.log_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.MutationLogger.log_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.MutationLogger.logManyTablets_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.MutationLogger.logManyTablets_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionFinished_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.MutationLogger.minorCompactionStarted_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.MutationLogger.minorCompactionStarted_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.MutationLogger.remove_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.MutationLogger.startCopy_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.MutationLogger.startCopy_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.NoSuchLogIDException._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.applyUpdate_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.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.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.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.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.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.setUpdateTablet_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.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.TabletClientService.useLoggers_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.TabletMutations._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.TestService.setTimeOffset_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.TestService.setTimeOffset_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.TooManyFilesException._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.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.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.Shell.CommandFactory.CodeType
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.zookeeper.ZooLock.LockLossReason
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.zookeeper.ZooUtil.NodeExistsPolicy
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.zookeeper.ZooUtil.NodeMissingPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
vectorSize - Variable in class org.apache.accumulo.core.bloomfilter.Filter
The vector size of this filter.
VERSION - Static variable in class org.apache.accumulo.core.Constants
 
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
 
VersioningIterator() - Constructor for class org.apache.accumulo.core.iterators.VersioningIterator
 
VersioningIterator(SortedKeyValueIterator<Key, Value>, int) - Constructor for class org.apache.accumulo.core.iterators.VersioningIterator
 
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
 
VisibilityEvaluator - Class in org.apache.accumulo.core.security
 
VisibilityEvaluator(Authorizations) - Constructor for class org.apache.accumulo.core.security.VisibilityEvaluator
The VisibilityEvaluator computes a trie from the given Authorizations, that ColumnVisibility expressions can be evaluated against.
VisibilityFilter - Class in org.apache.accumulo.core.iterators.filter
 
VisibilityFilter(Authorizations, byte[]) - Constructor for class org.apache.accumulo.core.iterators.filter.VisibilityFilter
 
VisibilityInterpreter - Interface in org.apache.accumulo.core.security
 
VisibilityInterpreterFactory - Class in org.apache.accumulo.core.security
 
VisibilityInterpreterFactory() - Constructor for class org.apache.accumulo.core.security.VisibilityInterpreterFactory
 
VisibilityParseException - Exception in org.apache.accumulo.core.security
 
VisibilityParseException(String, byte[], int) - Constructor for exception org.apache.accumulo.core.security.VisibilityParseException
 
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
 

W

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
 
wasLockAcquired() - Method in class org.apache.accumulo.core.zookeeper.ZooLock
indicates if the lock was acquired in the past....
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
 
WholeRowIterator - Class in org.apache.accumulo.core.iterators
The WholeRowIterator is designed to provide row-isolation so that queries see mutations as atomic.
WholeRowIterator() - Constructor for class org.apache.accumulo.core.iterators.WholeRowIterator
 
why - Variable in exception org.apache.accumulo.core.master.thrift.RecoveryException
 
WrappingIterator - Class in org.apache.accumulo.core.iterators
 
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(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.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.changePassword_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changePassword_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createUser_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropUser_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.finishBulkImport_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.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.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.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.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.listUsers_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listUsers_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.prepareBulkImport_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.prepareBulkImport_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 exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat.RangeInputSplit
 
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.TColumn
 
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.map.MySequenceFile.Metadata
Deprecated.  
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.RelativeKey
 
write(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.RFile.IndexEntry
 
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(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.LoggerStatus
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.createTable_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.deleteTable_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.flushTable_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.offlineTable_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.offlineTable_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.onlineTable_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.renameTable_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.renameTable_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.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.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.TabletInfo
 
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(TProtocol) - Method in class org.apache.accumulo.core.security.thrift.AuthInfo
 
write(TProtocol) - Method in exception org.apache.accumulo.core.security.thrift.ThriftSecurityException
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.CompactionStats
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.LogFile
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.close_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.create_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.defineTablet_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.getClosedLogs_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.log_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.logManyTablets_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionFinished_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.minorCompactionStarted_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.remove_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.MutationLogger.startCopy_result
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchLogIDException
 
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.applyUpdate_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.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.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.flush_args
 
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.loadTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.setUpdateTablet_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.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.TabletClientService.useLoggers_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletMutations
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TestService.setTimeOffset_result
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
writeCompressedBytes(DataOutputStream) - Method in interface org.apache.accumulo.core.file.map.MySequenceFile.ValueBytes
Deprecated. Write compressed bytes to outStream.
writeFile(MySequenceFile.Sorter.RawKeyValueIterator, MySequenceFile.Writer) - Method in class org.apache.accumulo.core.file.map.MySequenceFile.Sorter
Deprecated. Writes records from RawKeyValueIterator into a file represented by the passed writer
writeKey(OutputStream) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Writing the key to the output stream.
Writer - Class in org.apache.accumulo.core.client.impl
 
Writer(Instance, AuthInfo, Text) - Constructor for class org.apache.accumulo.core.client.impl.Writer
 
Writer(Instance, AuthInfo, String) - Constructor for class org.apache.accumulo.core.client.impl.Writer
 
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.
writeUncompressedBytes(DataOutputStream) - Method in interface org.apache.accumulo.core.file.map.MySequenceFile.ValueBytes
Deprecated. Writes the uncompressed bytes to the outStream.
writeValue(OutputStream) - Method in class org.apache.accumulo.core.file.rfile.bcfile.TFile.Reader.Scanner.Entry
Writing the value to the output stream.
writeVInt(DataOutput, int) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Encoding an integer into a variable-length encoding format.
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.

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

ZCONFIG - Static variable in class org.apache.accumulo.core.Constants
 
ZDOOMEDSERVERS - 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
 
ZINSTANCES - Static variable in class org.apache.accumulo.core.Constants
 
ZLOGGERS - 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
 
ZooCache - Class in org.apache.accumulo.core.zookeeper
Caches values stored in zookeeper and keeps them up to date as they change in zookeeper.
ZooCache() - Constructor for class org.apache.accumulo.core.zookeeper.ZooCache
 
ZooCache(String, int) - Constructor for class org.apache.accumulo.core.zookeeper.ZooCache
 
ZooCache(Watcher) - Constructor for class org.apache.accumulo.core.zookeeper.ZooCache
 
ZooCache(String, int, Watcher) - Constructor for class org.apache.accumulo.core.zookeeper.ZooCache
 
ZooConfiguration - Class in org.apache.accumulo.core.conf
 
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(UUID, String) - Constructor for class org.apache.accumulo.core.client.ZooKeeperInstance
 
ZooLock - Class in org.apache.accumulo.core.zookeeper
 
ZooLock(String) - Constructor for class org.apache.accumulo.core.zookeeper.ZooLock
 
ZooLock.AsyncLockWatcher - Interface in org.apache.accumulo.core.zookeeper
 
ZooLock.LockID - Class in org.apache.accumulo.core.zookeeper
 
ZooLock.LockID(String, String) - Constructor for class org.apache.accumulo.core.zookeeper.ZooLock.LockID
 
ZooLock.LockLossReason - Enum in org.apache.accumulo.core.zookeeper
 
ZooLock.LockWatcher - Interface in org.apache.accumulo.core.zookeeper
 
ZooSession - Class in org.apache.accumulo.core.zookeeper
 
ZooSession() - Constructor for class org.apache.accumulo.core.zookeeper.ZooSession
 
ZooUtil - Class in org.apache.accumulo.core.zookeeper
 
ZooUtil() - Constructor for class org.apache.accumulo.core.zookeeper.ZooUtil
 
ZooUtil.NodeExistsPolicy - Enum in org.apache.accumulo.core.zookeeper
 
ZooUtil.NodeMissingPolicy - Enum in org.apache.accumulo.core.zookeeper
 
ZPROBLEMS - 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.Constants
 
ZROOT_TABLET_FUTURE_LOCATION - Static variable in class org.apache.accumulo.core.Constants
 
ZROOT_TABLET_LAST_LOCATION - Static variable in class org.apache.accumulo.core.Constants
 
ZROOT_TABLET_LOCATION - Static variable in class org.apache.accumulo.core.Constants
 
ZROOT_TABLET_WALOGS - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_CONF - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_NAME - 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
 

_

_locateTablet(Text, boolean, boolean, boolean) - 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 © 2012 The Apache Software Foundation. All Rights Reserved.