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.