Index

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

ABSOLUTEPATH - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
AbstractEncoder<T> - Class in org.apache.accumulo.core.client.lexicoder
AbstractEncoder is an Encoder that implements all of Encoder's methods validating the input, but has those methods defer logic to a new method, AbstractEncoder.decodeUnchecked(byte[], int, int).
AbstractEncoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.AbstractEncoder
 
AbstractHashSampler - Class in org.apache.accumulo.core.client.sample
A base class that can be used to create Samplers based on hashing.
AbstractHashSampler() - Constructor for class org.apache.accumulo.core.client.sample.AbstractHashSampler
 
AbstractId<T extends AbstractId<T>> - Class in org.apache.accumulo.core.data
An abstract identifier class for comparing equality of identifiers of the same type.
AbstractId(String) - Constructor for class org.apache.accumulo.core.data.AbstractId
 
AbstractInputFormat<K,V> - Class in org.apache.accumulo.core.client.mapred
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
AbstractInputFormat<K,V> - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
AbstractInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
 
AbstractInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
 
AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapred
Deprecated.
An abstract base class to be used to create RecordReader instances that convert from Accumulo Key/Value pairs to the user's K/V types.
AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
An abstract base class to be used to create RecordReader instances that convert from Accumulo Key/Value pairs to the user's K/V types.
AbstractLexicoder<T> - Class in org.apache.accumulo.core.client.lexicoder
 
AbstractLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.AbstractLexicoder
 
AbstractRecordReader() - Constructor for class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
AbstractRecordReader() - Constructor for class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
accept(String, long) - Method in interface org.apache.accumulo.core.client.summary.Summarizer.StatisticConsumer
 
accept(Key) - Method in class org.apache.accumulo.core.client.sample.AbstractHashSampler
 
accept(Key) - Method in interface org.apache.accumulo.core.client.sample.Sampler
 
accept(Key, Value) - Method in interface org.apache.accumulo.core.client.summary.Summarizer.Collector
During compactions, Accumulo passes each Key Value written to the file to this method.
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.Filter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.ServerFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
Accepts entries whose timestamps are less than currentTime - threshold.
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.ReqVisFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iteratorsImpl.system.ColumnQualifierFilter
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SampleIterator
 
accept(Key, Value) - Method in class org.apache.accumulo.core.iteratorsImpl.system.VisibilityFilter
 
ACCEPTABLE_FACTOR_PROPERTY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
AcceptableException - Interface in org.apache.accumulo.core.fate
An exception for FATE operations to use to denote when an Exception is acceptable and should not trigger warning messages.
acceptableFactor(float) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
AcceptableThriftTableOperationException - Exception in org.apache.accumulo.core.clientImpl
Concrete implementation of AcceptableException for table operations.
AcceptableThriftTableOperationException(String, String, TableOperation, TableOperationExceptionType, String) - Constructor for exception org.apache.accumulo.core.clientImpl.AcceptableThriftTableOperationException
 
ACCEPTED - Enum constant in enum org.apache.accumulo.core.client.ConditionalWriter.Status
conditions were met and mutation was written
ACCEPTED - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TCMStatus
 
acceptRow(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
Implementation should return false to suppress a row.
access(long) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
Block has been accessed.
Accumulo - Class in org.apache.accumulo.core.client
This class contains all API entry points created in 2.0.0 or later.
ACCUMULO - Static variable in class org.apache.accumulo.core.clientImpl.Namespace
 
ACCUMULO_POOL_PREFIX - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
ACCUMULO_PROPERTIES - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.FileOutputConfigurator.Opts
 
AccumuloBulkMergeException - Exception in org.apache.accumulo.core.clientImpl
Internal class indicating a concurrent merge occurred during the new bulk import.
AccumuloBulkMergeException(Throwable) - Constructor for exception org.apache.accumulo.core.clientImpl.AccumuloBulkMergeException
 
AccumuloClient - Interface in org.apache.accumulo.core.client
Client connection to an Accumulo instance.
AccumuloClient.AuthenticationArgs<T> - Interface in org.apache.accumulo.core.client
Builder methods for authentication
AccumuloClient.ClientFactory<T> - Interface in org.apache.accumulo.core.client
Builds AccumuloClient or client Properties after all options have been specified
AccumuloClient.ConnectionOptions<T> - Interface in org.apache.accumulo.core.client
Build methods for connection options
AccumuloClient.FromOptions<T> - Interface in org.apache.accumulo.core.client
 
AccumuloClient.InstanceArgs<T> - Interface in org.apache.accumulo.core.client
Builder method for setting Accumulo instance and zookeepers
AccumuloClient.PropertyOptions<T> - Interface in org.apache.accumulo.core.client
Builder methods for creating AccumuloClient using properties
AccumuloClient.SaslOptions<T> - Interface in org.apache.accumulo.core.client
Build methods for SASL
AccumuloClient.SslOptions<T> - Interface in org.apache.accumulo.core.client
Build methods for SSL/TLS
AccumuloConfiguration - Class in org.apache.accumulo.core.conf
A configuration object.
AccumuloConfiguration() - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration
 
AccumuloConfiguration.Deriver<T> - Interface in org.apache.accumulo.core.conf
Automatically regenerates an object whenever configuration changes.
AccumuloConfiguration.ScanExecutorConfig - Class in org.apache.accumulo.core.conf
 
AccumuloDaemonThread(Runnable, String, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.accumulo.core.util.threads.Threads.AccumuloDaemonThread
 
AccumuloDaemonThread(String) - Constructor for class org.apache.accumulo.core.util.threads.Threads.AccumuloDaemonThread
 
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(String, Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloException
 
AccumuloException(Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloException
 
AccumuloFileOutputFormat - Class in org.apache.accumulo.core.client.mapred
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
AccumuloFileOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
Deprecated.
 
AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
Deprecated.
 
AccumuloInputFormat - Class in org.apache.accumulo.core.client.mapred
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
AccumuloInputFormat - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
AccumuloInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloInputFormat
Deprecated.
 
AccumuloInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
Deprecated.
 
AccumuloMultiTableInputFormat - Class in org.apache.accumulo.core.client.mapred
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
AccumuloMultiTableInputFormat - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
AccumuloMultiTableInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloMultiTableInputFormat
Deprecated.
 
AccumuloMultiTableInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
Deprecated.
 
AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapred
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
 
AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
 
AccumuloOutputFormat.AccumuloRecordWriter - Class in org.apache.accumulo.core.client.mapred
Deprecated.
A base class to be used to create RecordWriter instances that write to Accumulo.
AccumuloOutputFormat.AccumuloRecordWriter - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
A base class to be used to create RecordWriter instances that write to Accumulo.
AccumuloRecordWriter(JobConf) - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
Deprecated.
 
AccumuloRecordWriter(TaskAttemptContext) - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
Deprecated.
 
AccumuloReplicationReplayer - Interface in org.apache.accumulo.core.replication
Deprecated.
AccumuloRowInputFormat - Class in org.apache.accumulo.core.client.mapred
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapred instead from the accumulo-hadoop-mapreduce.jar
AccumuloRowInputFormat - Class in org.apache.accumulo.core.client.mapreduce
Deprecated.
since 2.0.0; Use org.apache.accumulo.hadoop.mapreduce instead from the accumulo-hadoop-mapreduce.jar
AccumuloRowInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloRowInputFormat
Deprecated.
 
AccumuloRowInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloRowInputFormat
Deprecated.
 
AccumuloSecurityException - Exception in org.apache.accumulo.core.client
An Accumulo Exception for security violations, authentication failures, authorization failures, etc.
AccumuloSecurityException(String, SecurityErrorCode) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloSecurityException(String, SecurityErrorCode, String) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloSecurityException(String, SecurityErrorCode, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloSecurityException(String, SecurityErrorCode, Throwable) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
 
AccumuloSecurityException(ThriftSecurityException) - Constructor for exception org.apache.accumulo.core.client.AccumuloSecurityException
Construct a user-facing exception from a serialized version.
AccumuloServerException - Exception in org.apache.accumulo.core.clientImpl
This class is intended to encapsulate errors that occurred on the server side.
AccumuloServerException(String, TApplicationException) - Constructor for exception org.apache.accumulo.core.clientImpl.AccumuloServerException
 
AccumuloTFramedTransportFactory - Class in org.apache.accumulo.core.rpc
This is a workaround for the issue reported in https://issues.apache.org/jira/browse/THRIFT-5732 and can be removed once that issue is fixed.
AccumuloTFramedTransportFactory(int) - Constructor for class org.apache.accumulo.core.rpc.AccumuloTFramedTransportFactory
 
acquire(long) - Method in class org.apache.accumulo.core.util.ratelimit.GuavaRateLimiter
 
acquire(long) - Method in class org.apache.accumulo.core.util.ratelimit.NullRateLimiter
 
acquire(long) - Method in interface org.apache.accumulo.core.util.ratelimit.RateLimiter
Sleep until the specified number of queries are available.
acquire(long) - Method in class org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory.SharedRateLimiter
 
acquiredLock() - Method in interface org.apache.accumulo.core.fate.zookeeper.ServiceLock.AccumuloLockWatcher
 
ActionStats - Class in org.apache.accumulo.core.tabletserver.thrift
 
ActionStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
ActionStats(int, double, int, long, double, int, double, double) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
ActionStats(ActionStats) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActionStats
Performs a deep copy on other.
ActionStats._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActiveCompaction - Class in org.apache.accumulo.core.client.admin
 
ActiveCompaction - Class in org.apache.accumulo.core.tabletserver.thrift
 
ActiveCompaction() - Constructor for class org.apache.accumulo.core.client.admin.ActiveCompaction
 
ActiveCompaction() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
ActiveCompaction(TKeyExtent, long, List<String>, String, TCompactionType, TCompactionReason, String, long, long, List<IterInfo>, Map<String, Map<String, String>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
ActiveCompaction(ActiveCompaction) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Performs a deep copy on other.
ActiveCompaction._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActiveCompaction.CompactionHost - Interface in org.apache.accumulo.core.client.admin
 
ActiveCompaction.CompactionHost.Type - Enum in org.apache.accumulo.core.client.admin
 
ActiveCompaction.CompactionReason - Enum in org.apache.accumulo.core.client.admin
 
ActiveCompaction.CompactionType - Enum in org.apache.accumulo.core.client.admin
 
ActiveCompactionImpl - Class in org.apache.accumulo.core.clientImpl
 
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.client.admin.ActiveScan
 
ActiveScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
ActiveScan(String, String, String, long, long, ScanType, ScanState, TKeyExtent, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, 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.
ActiveScanImpl - Class in org.apache.accumulo.core.clientImpl
A class that contains information about an ActiveScan
add(boolean) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
Adds a Boolean value to this writer's buffer.
add(byte[], int, int) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
Adds bytes to this writer's buffer.
add(List<ConstraintViolationSummary>) - Method in class org.apache.accumulo.core.constraints.Violations
Adds a list of violations.
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(Bulk.FileInfo) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
add(Violations) - Method in class org.apache.accumulo.core.constraints.Violations
Adds all violations from the given object to this one.
add(ConstraintViolationSummary) - Method in class org.apache.accumulo.core.constraints.Violations
Adds a violation.
add(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
 
add(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Writer
 
add(Mutation, TableId, Value) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
Deprecated.
Add a column update to the given mutation with the provided tableId and value
add(Mutation, TableId, Value) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.StatusSection
Deprecated.
 
add(Mutation, Text, Value) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.WorkSection
Deprecated.
 
add(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlockQueue
Attempt to add the specified cached block to this queue.
add(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
add(ColumnVisibility.Node) - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
add(Text) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnSet
 
add(Text, Text) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnSet
 
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.
addAssignment(TabletId, TabletServerId) - Method in class org.apache.accumulo.core.manager.balancer.AssignmentParamsImpl
 
addAssignment(TabletId, TabletServerId) - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer.AssignmentParameters
Assigns tabletId to tabletServerId.
addBulkLoadInProgressFlag(String, long) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Create a Bulk Load In Progress flag in the metadata table
addCacheFile(String, String, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.DistributedCacheHelper
 
addCacheFile(Job, String, String) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.DistributedCacheHelper
 
addCommonTags(List<Tag>) - Method in interface org.apache.accumulo.core.metrics.MetricsInfo
Add the list of tag name / value pair to the common tags that will be emitted with all metrics.
addCondition(Condition) - Method in class org.apache.accumulo.core.data.ConditionalMutation
 
addConstraint(String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Add a new constraint to a namespace.
addConstraint(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Add a new constraint to a table.
addConstraint(String, String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
addConstraint(String, String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
addConstraint(String, String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
addConstraint(String, String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
addEntry(byte[]) - Method in interface org.apache.accumulo.core.fate.zookeeper.DistributedReadWriteLock.QueueLock
 
addEntry(byte[]) - Method in class org.apache.accumulo.core.fate.zookeeper.FateLock
 
addIterator(Class<?>, Configuration, IteratorSetting) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Encode an iterator on the input for the single input table associated with this job.
addIterator(JobConf, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Deprecated.
Encode an iterator on the input for this job.
addIterator(Job, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Deprecated.
Encode an iterator on the single input table for this job.
addJob(short, CompactionExecutorId, Collection<CompactableFile>) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlan.Builder
 
addJob(short, CompactionExecutorId, Collection<CompactableFile>) - Method in class org.apache.accumulo.core.util.compaction.CompactionPlanImpl.BuilderImpl
 
addLast(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
 
addLast(Key, int, long, long, long) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Writer
 
addMetric(Key, Value) - Method in interface org.apache.accumulo.core.file.rfile.MetricsGatherer
Collect and store metrics for the given entry.
addMetric(Key, Value) - Method in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
addMetricsProducers(MetricsProducer...) - Method in interface org.apache.accumulo.core.metrics.MetricsInfo
 
addMigration(KeyExtent, TServerInstance, TServerInstance) - Method in class org.apache.accumulo.core.manager.balancer.BalanceParamsImpl
 
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.clientImpl.BatchWriterImpl
 
addMutation(TableId, Iterator<Mutation>) - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchWriter
 
addMutation(TableId, Mutation) - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchWriter
 
addMutation(KeyExtent, T) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletServerMutations
 
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.clientImpl.BatchWriterImpl
 
addNamedOption(String, String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
addObject(Text, K) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnToClassMapping
 
addObject(Text, Text, K) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnToClassMapping
 
addOption(String, long) - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration.Builder
Adds an option that Summarizers can use when constructing Collectors and Combiners.
addOption(String, String) - Method in class org.apache.accumulo.core.client.IteratorSetting
Add another option to the iterator.
addOption(String, String) - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
addOption(String, String) - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration.Builder
Adds an option that Summarizers can use when constructing Collectors and Combiners.
addOptions(String...) - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration.Builder
Convenience method for adding multiple options.
addOptions(Map<String, String>) - Method in class org.apache.accumulo.core.client.IteratorSetting
Add many options to the iterator.
addOptions(Map<String, String>) - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration.Builder
 
addOptions(Set<Map.Entry<String, String>>) - Method in class org.apache.accumulo.core.client.IteratorSetting
Add many options to the iterator.
addPeer(String, String) - Method in interface org.apache.accumulo.core.client.admin.ReplicationOperations
Deprecated.
Defines a cluster with the given name and the given name system.
addPeer(String, String) - Method in class org.apache.accumulo.core.clientImpl.ReplicationOperationsImpl
Deprecated.
 
addPlan(LoadPlan) - Method in interface org.apache.accumulo.core.data.LoadPlan.Builder
 
addRange(Map<String, Map<KeyExtent, List<Range>>>, String, KeyExtent, Range) - Static method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
addRegistry(MeterRegistry) - Method in interface org.apache.accumulo.core.metrics.MetricsInfo
 
addReplicationSource(String) - Method in class org.apache.accumulo.core.data.Mutation
Deprecated.
The feature pertaining to this method was deprecated in 2.1.0, but this method was overlooked when annotating the code. It is being marked as deprecated in 2.1.1 in order to correct that oversight, and will be removed in 3.0.0 with the rest of the code pertaining to this feature.
addressTags(HostAndPort) - Static method in interface org.apache.accumulo.core.metrics.MetricsInfo
Convenience method to create tag name / value pairs for the host and port from address host:port pair.
AddressUtil - Class in org.apache.accumulo.core.util
 
AddressUtil() - Constructor for class org.apache.accumulo.core.util.AddressUtil
 
addScanIterator(IteratorSetting) - Method in interface org.apache.accumulo.core.client.ScannerBase
Add a server-side scan iterator.
addScanIterator(IteratorSetting) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
addServiceTags(String, HostAndPort) - Method in interface org.apache.accumulo.core.metrics.MetricsInfo
Convenience method to set the common tags for application (process), host and port.
addSource(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
addSplits(String, SortedSet<Text>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Ensures that tablets are split along a set of keys.
addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
addStat(long) - Method in class org.apache.accumulo.core.util.Stat
 
addSummarizers(String, SummarizerConfiguration...) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Enables summary generation for this table for future compactions.
addSummarizers(String, SummarizerConfiguration...) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
addTable(Text) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
Deprecated.
 
addTable(Text) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
Deprecated.
 
addToArguments(ByteBuffer) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
addToBulkImports(BulkImportStatus) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
addToBulkImports(BulkImportStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
addToConditions(TCondition) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
addToDeadTabletServers(DeadServer) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
addToEdits(ByteBuffer) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
addToFilenames(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
addToFiles(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
addToFiles(InputFile) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
addToFullScans(TKeyExtent) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
addToInputFiles(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
addToIterators(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
addToKeyValues(TKeyValue) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
addToLogSorts(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
addToLogsToWatch(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
addToMutations(TMutation) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
addToNewTablets(TKeyExtent) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
addToResults(TKeyValue) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
addToResults(TKeyValue) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
addToServersShuttingDown(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
addToSources(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
addToSuccess(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
addToSuccess(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
addToSuccess(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
addToSuccess(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
addToSuccess(ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
addToSuccess(TDiskUsage) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
addToSuccess(TCMResult) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
addToSuccess(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
addToSuccess(ActiveCompaction) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
addToSuccess(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
addToSuccess(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
addToSuccess(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
addToSuccess(TCompactionQueueSummary) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
addToSummaries(TSummary) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
addToSummarizers(TSummarizerConfiguration) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
addToSymbols(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
addToTables(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
addToTables(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
addToTServerInfo(TabletServerStatus) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
addToValues(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
addToViolationSummaries(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
addToViolationSummaries(TConstraintViolationSummary) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
addTTL(IteratorSetting, IteratorSetting.Column, Long) - Static method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
A convenience method for adding or changing an age off threshold for a column.
addUnnamedOption(String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
addUpdate(Long, TCompactionStatusUpdate) - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
AdminUtil<T> - Class in org.apache.accumulo.core.fate
A utility to administer FATE operations
AdminUtil(boolean) - Constructor for class org.apache.accumulo.core.fate.AdminUtil
Constructor
AdminUtil.FateStatus - Class in org.apache.accumulo.core.fate
 
AdminUtil.TransactionStatus - Class in org.apache.accumulo.core.fate
FATE transaction status, including lock information.
advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
AESCBCCryptoModule(Key, String, String) - Constructor for class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule
 
AESCryptoService - Class in org.apache.accumulo.core.spi.crypto
Example implementation of AES encryption for Accumulo
AESCryptoService() - Constructor for class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
AESCryptoService.AESCBCCryptoModule - Class in org.apache.accumulo.core.spi.crypto
 
AESCryptoService.AESCBCCryptoModule.AESCBCFileDecrypter - Class in org.apache.accumulo.core.spi.crypto
 
AESCryptoService.AESCBCCryptoModule.AESCBCFileEncrypter - Class in org.apache.accumulo.core.spi.crypto
 
AESCryptoService.AESGCMCryptoModule - Class in org.apache.accumulo.core.spi.crypto
 
AESCryptoService.AESGCMCryptoModule.AESGCMFileDecrypter - Class in org.apache.accumulo.core.spi.crypto
 
AESCryptoService.AESGCMCryptoModule.AESGCMFileEncrypter - Class in org.apache.accumulo.core.spi.crypto
 
AESGCMCryptoModule(Key, String, String) - Constructor for class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule
 
afterEndKey(Key) - Method in class org.apache.accumulo.core.data.Range
Determines if the given key is after the ending key of this range.
age - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
age - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
AGE - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
AGE - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
ageOff() - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
AgeOffFilter - Class in org.apache.accumulo.core.iterators.user
A filter that ages off key/value pairs based on the Key's timestamp.
AgeOffFilter() - Constructor for class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
AgeOffStore<T> - Class in org.apache.accumulo.core.fate
This store removes Repos, in the store it wraps, that are in a finished or new state for more than a configurable time period.
AgeOffStore(ZooStore<T>, long, AgeOffStore.TimeSource) - Constructor for class org.apache.accumulo.core.fate.AgeOffStore
 
AgeOffStore.TimeSource - Interface in org.apache.accumulo.core.fate
 
aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
Generate statistics from each Map.Entry, called for each entry to be iterated over.
aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
 
aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
 
AggregatingFormatter - Class in org.apache.accumulo.core.util.format
Formatter that will aggregate entries for various display purposes.
AggregatingFormatter() - Constructor for class org.apache.accumulo.core.util.format.AggregatingFormatter
 
align(int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Aligns a number to 8.
align(long) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Aligns a number to 8.
ALL_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
 
ALTER_NAMESPACE - Enum constant in enum org.apache.accumulo.core.security.NamespacePermission
 
ALTER_NAMESPACE - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
ALTER_TABLE - Enum constant in enum org.apache.accumulo.core.security.NamespacePermission
 
ALTER_TABLE - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
ALTER_TABLE - Enum constant in enum org.apache.accumulo.core.security.TablePermission
 
ALTER_USER - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
Ample - Interface in org.apache.accumulo.core.metadata.schema
Accumulo Metadata Persistence Layer.
Ample.DataLevel - Enum in org.apache.accumulo.core.metadata.schema
Accumulo is a distributed tree with three levels.
Ample.GcCandidateType - Enum in org.apache.accumulo.core.metadata.schema
Enables status based processing of GcCandidates.
Ample.ReadConsistency - Enum in org.apache.accumulo.core.metadata.schema
Controls how Accumulo metadata is read.
Ample.TabletMutator - Interface in org.apache.accumulo.core.metadata.schema
Interface for changing a tablets persistent data.
Ample.TabletsMutator - Interface in org.apache.accumulo.core.metadata.schema
This interface allows efficiently updating multiple tablets.
AmpleImpl - Class in org.apache.accumulo.core.metadata.schema
 
AmpleImpl(AccumuloClient) - Constructor for class org.apache.accumulo.core.metadata.schema.AmpleImpl
 
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
Performs a logical AND between this filter and a specified filter.
and(Validator<T>) - Method in class org.apache.accumulo.core.util.Validator
Creates a new validator that is the conjunction of this one and the given one.
AND - Enum constant in enum org.apache.accumulo.core.security.ColumnVisibility.NodeType
 
append(Iterable<Map.Entry<Key, Value>>) - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
Append the keys and values to the last locality group that was started.
append(Key, byte[]) - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
This method has the same behavior as RFileWriter.append(Key, Value).
append(Key, CharSequence) - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
This method has the same behavior as RFileWriter.append(Key, Value).
append(Key, Value) - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
Append the key and value to the last locality group that was started.
append(Key, Value) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
append(Key, Value) - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
append(Key, Value) - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
append(Key, Value) - Method in interface org.apache.accumulo.core.iterators.user.TransformingIterator.KVBuffer
 
append(Key, Value) - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
appendPrintableString(byte[], int, int, int, StringBuilder) - Static method in class org.apache.accumulo.core.data.Key
Appends ASCII printable characters to a string, based on the given byte array, treating the bytes as ASCII characters.
appendText(StringBuilder, Text, int) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
apply(ZooKeeper) - Method in interface org.apache.accumulo.core.fate.zookeeper.ZooReader.ZKFunction
 
apply(ZooKeeper) - Method in interface org.apache.accumulo.core.fate.zookeeper.ZooReader.ZKFunctionMutator
 
applyUpdates() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
 
applyUpdates() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
 
applyUpdates(TInfo, long, TKeyExtent, List<TMutation>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
applyUpdates(TInfo, long, TKeyExtent, List<TMutation>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
applyUpdates(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
applyUpdates(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
applyUpdates_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
applyUpdates_args(TabletClientService.applyUpdates_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
Performs a deep copy on other.
applyUpdates_args(TInfo, long, TKeyExtent, List<TMutation>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
applyUpdates_call(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.applyUpdates_call
 
APPNAME - Static variable in class org.apache.accumulo.core.Constants
 
arguments - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
ARGUMENTS - Enum constant in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
ARRAY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Array overhead
arrayAdd(List<Long>, List<Long>) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
ArrayByteSequence - Class in org.apache.accumulo.core.data
An implementation of ByteSequence that uses a backing byte array.
ArrayByteSequence(byte[]) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
Creates a new sequence.
ArrayByteSequence(byte[], int, int) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
Creates a new sequence from a subsequence of the given byte array.
ArrayByteSequence(String) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
Creates a new sequence from the given string.
ArrayByteSequence(ByteBuffer) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
Creates a new sequence based on a byte buffer.
ArrayByteSequence(ByteSequence) - Constructor for class org.apache.accumulo.core.data.ArrayByteSequence
Copy constructor.
as(CharSequence, CharSequence) - Method in interface org.apache.accumulo.core.client.AccumuloClient.AuthenticationArgs
Build using password-based credentials
as(CharSequence, CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
as(CharSequence, Path) - Method in interface org.apache.accumulo.core.client.AccumuloClient.AuthenticationArgs
Build using Kerberos credentials
as(CharSequence, Path) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
as(CharSequence, AuthenticationToken) - Method in interface org.apache.accumulo.core.client.AccumuloClient.AuthenticationArgs
Build using specified credentials
as(CharSequence, AuthenticationToken) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
asList() - Method in class org.apache.accumulo.core.constraints.Violations
Gets the violations as a list of summaries.
assigned(KeyExtent, TServerInstance) - Static method in class org.apache.accumulo.core.logging.TabletLogger
A decision was made to assign a tablet to a tablet server process.
ASSIGNED - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TCompactionState
 
ASSIGNED - Enum constant in enum org.apache.accumulo.core.metadata.TabletState
 
ASSIGNED_TO_DEAD_SERVER - Enum constant in enum org.apache.accumulo.core.metadata.TabletState
 
ASSIGNING - Enum constant in enum org.apache.accumulo.core.master.thrift.BulkImportState
 
AssignmentParamsImpl - Class in org.apache.accumulo.core.manager.balancer
 
AssignmentParamsImpl(SortedMap<TabletServerId, TServerStatus>, Map<TabletId, TabletServerId>, Map<TabletId, TabletServerId>) - Constructor for class org.apache.accumulo.core.manager.balancer.AssignmentParamsImpl
 
asThriftException() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
asWriter(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
asWriter(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor
 
AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor
 
at() - Method in class org.apache.accumulo.core.data.Mutation
Fluent API for putting or deleting to a Mutation that makes it easy use different types (i.e byte[], CharSequence, etc) when specifying the family, qualifier, value, etc.
ATOMIC_INTEGER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Overhead for AtomicInteger
atPriority(OptionalInt) - Method in class org.apache.accumulo.core.util.threads.ThreadPools.ThreadPoolExecutorBuilder
 
attachIterator(String, IteratorSetting) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Add an iterator to a namespace on all scopes.
attachIterator(String, IteratorSetting) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Add an iterator to a table on all scopes.
attachIterator(String, IteratorSetting) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
attachIterator(String, IteratorSetting) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Add an iterator to a namespace on the given scopes.
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Add an iterator to a table on the given scopes.
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
attachIterator(IteratorSetting) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Configure iterator settings for a table prior to its creation.
attachIterator(IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Configure iterator settings for a table prior to its creation.
attempt(ZooReaderWriter, String, String, String) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooReservation
 
attemptPlans - Variable in class org.apache.accumulo.core.spi.scan.ConfigurableScanServerSelector.Profile
 
auth(ZooKeeper, String, byte[]) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
 
AUTH - Enum constant in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
 
AUTH_CONF - Enum constant in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
 
AUTH_INT - Enum constant in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
 
AUTH_OPT - Static variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
AUTH_PRINCIPAL - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
AUTH_TOKEN - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
AUTH_TYPE - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
AuthConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.AuthConverter
 
authenticate() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticate
 
authenticate() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticate
 
authenticate(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
authenticate(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
authenticate(TInfo, TCredentials, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
authenticate(TInfo, TCredentials, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
authenticate_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
authenticate_args(ClientService.authenticate_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
Performs a deep copy on other.
authenticate_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
authenticate_call(TInfo, TCredentials, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.authenticate_call
 
authenticate_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
authenticate_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
authenticate_result(ClientService.authenticate_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
Performs a deep copy on other.
authenticateUser() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticateUser
 
authenticateUser() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticateUser
 
authenticateUser(String, AuthenticationToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Verify a username/password combination is valid
authenticateUser(String, AuthenticationToken) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
authenticateUser(TInfo, TCredentials, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
authenticateUser(TInfo, TCredentials, TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
authenticateUser(TInfo, TCredentials, TCredentials, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
authenticateUser(TInfo, TCredentials, TCredentials, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
authenticateUser_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
authenticateUser_args(ClientService.authenticateUser_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
Performs a deep copy on other.
authenticateUser_args(TInfo, TCredentials, TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
authenticateUser_call(TInfo, TCredentials, TCredentials, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.authenticateUser_call
 
authenticateUser_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
authenticateUser_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
authenticateUser_result(ClientService.authenticateUser_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
Performs a deep copy on other.
AuthenticationToken - Interface in org.apache.accumulo.core.client.security.tokens
 
AuthenticationToken.AuthenticationTokenSerializer - Class in org.apache.accumulo.core.client.security.tokens
A utility class to serialize/deserialize AuthenticationToken objects.
Unfortunately, these methods are provided in an inner-class, to avoid breaking the interface API.
AuthenticationToken.Properties - Class in org.apache.accumulo.core.client.security.tokens
 
AuthenticationToken.TokenProperty - Class in org.apache.accumulo.core.client.security.tokens
 
AuthenticationTokenIdentifier - Class in org.apache.accumulo.core.clientImpl
Implementation that identifies the underlying Token for Accumulo.
AuthenticationTokenIdentifier() - Constructor for class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
AuthenticationTokenIdentifier(TAuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
AuthenticationTokenSerializer() - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
 
AUTHENTICATOR_FAILED - Enum constant in enum org.apache.accumulo.core.client.security.SecurityErrorCode
 
AUTHENTICATOR_FAILED - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
AUTHORIZATION_FAILURES - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
 
AuthorizationContainer - Interface in org.apache.accumulo.core.security
An interface for classes that contain a collection of authorizations.
authorizationFailures - Variable in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
authorizations - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
authorizations - Variable in class org.apache.accumulo.core.iteratorsImpl.system.VisibilityFilter
 
authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
Authorizations - Class in org.apache.accumulo.core.security
A collection of authorization strings.
Authorizations() - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an empty set of authorizations.
Authorizations(byte[]) - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an authorizations object from a serialized form.
Authorizations(String...) - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an authorizations object from a set of human-readable authorizations.
Authorizations(Collection<byte[]>) - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an authorization object from a collection of string authorizations that have each already been encoded as UTF-8 bytes.
Authorizations(List<ByteBuffer>) - Constructor for class org.apache.accumulo.core.security.Authorizations
Constructs an authorization object from a list of string authorizations that have each already been encoded as UTF-8 bytes.
AUTHORIZATIONS - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.ScanOpts
 
AUTHORIZATIONS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
 
AUTHORIZATIONS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
AUTHORIZATIONS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
 
AUTHORIZATIONS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
AUTHORIZATIONS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
AuthorizationSummarizer - Class in org.apache.accumulo.core.client.summary.summarizers
Counts unique authorizations in column visibility labels.
AuthorizationSummarizer() - Constructor for class org.apache.accumulo.core.client.summary.summarizers.AuthorizationSummarizer
 
AUTHORIZOR_FAILED - Enum constant in enum org.apache.accumulo.core.client.security.SecurityErrorCode
 
AUTHORIZOR_FAILED - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
auths - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
auto() - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
Build a SiteConfiguration from the environmental configuration and no overrides.
AUTO_ADJUST_RANGES - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.Features
 
AUTO_CLEAN - Enum constant in enum org.apache.accumulo.core.fate.Fate.TxInfo
 
AUTO_CLEAN - Enum constant in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
autoClean - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
available() - Method in class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
available() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
available() - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
 
availableSince() - Method in enum org.apache.accumulo.core.conf.Property
Gets the version in which the property was introduced.

B

backOffFactor(double) - Method in interface org.apache.accumulo.core.util.Retry.NeedsBackOffFactor
 
BAD_AUTHORIZATIONS - Enum constant in enum org.apache.accumulo.core.client.security.SecurityErrorCode
 
BAD_AUTHORIZATIONS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
BAD_CREDENTIALS - Enum constant in enum org.apache.accumulo.core.client.security.SecurityErrorCode
 
BAD_CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
BAD_RANGE - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
BAD_TSERVERS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
BadArgumentException - Exception in org.apache.accumulo.core.util
 
BadArgumentException(String, String, int) - Constructor for exception org.apache.accumulo.core.util.BadArgumentException
 
BadLocationStateException(String, Text) - Constructor for exception org.apache.accumulo.core.metadata.TabletLocationState.BadLocationStateException
 
badTServers - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
balance(TabletBalancer.BalanceParameters) - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
balance(TabletBalancer.BalanceParameters) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
balance(TabletBalancer.BalanceParameters) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
balance(TabletBalancer.BalanceParameters) - Method in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
balance(TabletBalancer.BalanceParameters) - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer
Ask the balancer if any migrations are necessary.
BalanceParamsImpl - Class in org.apache.accumulo.core.manager.balancer
 
BalanceParamsImpl(SortedMap<TabletServerId, TServerStatus>, Set<TabletId>, List<TabletMigration>) - Constructor for class org.apache.accumulo.core.manager.balancer.BalanceParamsImpl
 
BalancerEnvironment - Interface in org.apache.accumulo.core.spi.balancer
This interface is an extension of ServiceEnvironment that exposes system level information that is specific to tablet balancing.
BasicCacheProvider - Class in org.apache.accumulo.core.file.blockfile.impl
 
BasicCacheProvider(BlockCache, BlockCache) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.BasicCacheProvider
 
batch - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
BATCH - Enum constant in enum org.apache.accumulo.core.client.admin.ScanType
 
BATCH - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ScanType
 
BATCH - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
BATCH_SCANNER - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.Features
 
BATCH_SCANNER_NUM_QUERY_THREADS - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
BATCH_SCANNER_THREADS - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.Features
 
BATCH_SIZE - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
BATCH_TIME_OUT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
BATCH_TIME_OUT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
BATCH_WRITER_BIN_MUTATIONS_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
BATCH_WRITER_CONFIG - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.OutputConfigurator.WriteOpts
 
BATCH_WRITER_DURABILITY - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
BATCH_WRITER_LATENCY_MAX - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
BATCH_WRITER_MEMORY_MAX - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
BATCH_WRITER_SEND_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
BATCH_WRITER_THREADS_MAX - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
BATCH_WRITER_TIMEOUT_MAX - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
BatchDeleter - Interface in org.apache.accumulo.core.client
Implementations of BatchDeleter support efficient deletion of ranges in accumulo.
BatchInputSplit - Class in org.apache.accumulo.core.clientImpl.mapred
Deprecated.
since 2.0.0
BatchInputSplit - Class in org.apache.accumulo.core.clientImpl.mapreduce
Deprecated.
since 2.0.0
BatchInputSplit() - Constructor for class org.apache.accumulo.core.clientImpl.mapred.BatchInputSplit
Deprecated.
 
BatchInputSplit() - Constructor for class org.apache.accumulo.core.clientImpl.mapreduce.BatchInputSplit
Deprecated.
 
BatchInputSplit(String, TableId, Collection<Range>, String[]) - Constructor for class org.apache.accumulo.core.clientImpl.mapred.BatchInputSplit
Deprecated.
 
BatchInputSplit(String, TableId, Collection<Range>, String[]) - Constructor for class org.apache.accumulo.core.clientImpl.mapreduce.BatchInputSplit
Deprecated.
 
BatchInputSplit(BatchInputSplit) - Constructor for class org.apache.accumulo.core.clientImpl.mapred.BatchInputSplit
Deprecated.
 
BatchInputSplit(BatchInputSplit) - Constructor for class org.apache.accumulo.core.clientImpl.mapreduce.BatchInputSplit
Deprecated.
 
BatchScanner - Interface in org.apache.accumulo.core.client
In exchange for possibly returning scanned entries out of order, BatchScanner implementations may scan an Accumulo table more efficiently by Looking up multiple ranges in parallel.
batchScannerQueryThreads(int) - Method in interface org.apache.accumulo.core.client.AccumuloClient.ConnectionOptions
Build with default number of query threads for BatchScanner
batchScannerQueryThreads(int) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
batchSize - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
batchTimeout - Variable in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
batchTimeOut - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
batchTimeOut - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
BatchWriter - Interface in org.apache.accumulo.core.client
Send Mutations to a single Table in Accumulo.
batchWriterAndClientCloser(Object, Logger, BatchWriter, AccumuloClient) - Static method in class org.apache.accumulo.core.util.cleaner.CleanerUtil
 
batchWriterConfig(BatchWriterConfig) - Method in interface org.apache.accumulo.core.client.AccumuloClient.ConnectionOptions
Build with BatchWriterConfig defaults for BatchWriter, MultiTableBatchWriter & BatchDeleter
batchWriterConfig(BatchWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
BatchWriterConfig - Class in org.apache.accumulo.core.client
This object holds configuration settings used to instantiate a BatchWriter
BatchWriterConfig() - Constructor for class org.apache.accumulo.core.client.BatchWriterConfig
 
BatchWriterImpl - Class in org.apache.accumulo.core.clientImpl
 
BatchWriterImpl(ClientContext, TableId, BatchWriterConfig) - Constructor for class org.apache.accumulo.core.clientImpl.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.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.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
Determines if the given key is before the start key of this range.
beginFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.beginFateOperation
 
beginFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Processor.beginFateOperation
 
beginFateOperation(TInfo, TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
beginFateOperation(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.Iface
 
beginFateOperation(TInfo, TCredentials, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient
 
beginFateOperation(TInfo, TCredentials, AsyncMethodCallback<Long>) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.AsyncIface
 
beginFateOperation_args() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
beginFateOperation_args(FateService.beginFateOperation_args) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
Performs a deep copy on other.
beginFateOperation_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
beginFateOperation_call(TInfo, TCredentials, AsyncMethodCallback<Long>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.beginFateOperation_call
 
beginFateOperation_result() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
beginFateOperation_result(long, ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
beginFateOperation_result(FateService.beginFateOperation_result) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
Performs a deep copy on other.
BigDecimalCombiner - Class in org.apache.accumulo.core.iterators.user
A family of combiners that treat values as BigDecimals, encoding and decoding using the built-in BigDecimal String input/output functions.
BigDecimalCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
 
BigDecimalCombiner.BigDecimalEncoder - Class in org.apache.accumulo.core.iterators.user
Provides the ability to encode scientific notation.
BigDecimalCombiner.BigDecimalMaxCombiner - Class in org.apache.accumulo.core.iterators.user
 
BigDecimalCombiner.BigDecimalMinCombiner - Class in org.apache.accumulo.core.iterators.user
 
BigDecimalCombiner.BigDecimalSummingCombiner - Class in org.apache.accumulo.core.iterators.user
 
BigDecimalEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
 
BigDecimalMaxCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalMaxCombiner
 
BigDecimalMinCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalMinCombiner
 
BigDecimalSummingCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalSummingCombiner
 
BigIntegerLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder to encode/decode a BigInteger to/from bytes that maintain its native Java sort order.
BigIntegerLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
 
bigNumberForQuantity(double) - Static method in class org.apache.accumulo.core.util.NumUtil
 
bigNumberForQuantity(long) - Static method in class org.apache.accumulo.core.util.NumUtil
 
bigNumberForSize(long) - Static method in class org.apache.accumulo.core.util.NumUtil
 
BinaryFormatter - Class in org.apache.accumulo.core.util.format
Deprecated.
since 1.8.0; Use DefaultFormatter providing showLength and printTimestamps via FormatterConfig.
BinaryFormatter() - Constructor for class org.apache.accumulo.core.util.format.BinaryFormatter
Deprecated.
 
binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator
 
binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.clientImpl.TimeoutTabletLocator
 
binOffline(TableId, List<Range>, ClientContext) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
 
binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator
 
binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.clientImpl.TimeoutTabletLocator
 
BlipSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
 
BlockCache - Interface in org.apache.accumulo.core.spi.cache
Block cache interface.
BlockCache.Loader - Interface in org.apache.accumulo.core.spi.cache
 
BlockCache.Stats - Interface in org.apache.accumulo.core.spi.cache
Cache statistics.
BlockCacheConfiguration - Class in org.apache.accumulo.core.file.blockfile.cache.impl
 
BlockCacheManager - Class in org.apache.accumulo.core.spi.cache
 
BlockCacheManager() - Constructor for class org.apache.accumulo.core.spi.cache.BlockCacheManager
 
BlockCacheManager.Configuration - Interface in org.apache.accumulo.core.spi.cache
 
BlockCacheManagerFactory - Class in org.apache.accumulo.core.file.blockfile.cache.impl
 
BlockCacheManagerFactory() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheManagerFactory
 
BlockedInputStream - Class in org.apache.accumulo.core.crypto.streams
Reader corresponding to BlockedOutputStream.
BlockedInputStream(InputStream, int, int) - Constructor for class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
BlockedOutputStream - Class in org.apache.accumulo.core.crypto.streams
Buffers all input in a growing buffer until flush() is called.
BlockedOutputStream(OutputStream, int, int) - Constructor for class org.apache.accumulo.core.crypto.streams.BlockedOutputStream
 
BlockIndex - Class in org.apache.accumulo.core.file.rfile
 
BlockIndex.BlockIndexEntry - Class in org.apache.accumulo.core.file.rfile
 
BlockIndexEntry(int, int, Key) - Constructor for class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
BlockIndexEntry(Key) - Constructor for class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
blocks - Variable in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
BLOOM_FILE_NAME - Static variable in class org.apache.accumulo.core.file.BloomFilterLayer
 
BLOOM_LOADER_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
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.Writer - Class in org.apache.accumulo.core.file
 
BOOLEAN - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
bound(Column, Column) - Method in class org.apache.accumulo.core.data.Range
Creates a new range that is bounded by the columns passed in.
BoundedRangeFileInputStream - Class in org.apache.accumulo.core.file.streams
BoundedRangeFIleInputStream abstracts a contiguous region of a Hadoop FSDataInputStream as a regular input stream.
BoundedRangeFileInputStream(StreamType, long, long) - Constructor for class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
Constructor
bounds - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
BOUNDS - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
 
BufferedWriter(MultiLevelIndex.Writer) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
 
bufferForCf() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
bufferForColFamily() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
bufferForColQualifier() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
bufferForColumnFamily() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
bufferForColumnQualifier() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
bufferForColumnVisibility() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
bufferForColVisibility() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
bufferForCq() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
bufferForCv() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
bufferForData() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
bufferForEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
bufferForEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
bufferForEndRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
bufferForEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
bufferForEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
bufferForIterators() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
bufferForPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
bufferForPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
bufferForPassword() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
bufferForPrevEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
bufferForRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
bufferForRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
bufferForSecret() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
bufferForSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
bufferForStartRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
bufferForStartRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
bufferForStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
bufferForStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
bufferForTable() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
bufferForToken() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
bufferForVal() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
bufferForValue() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
build() - Method in interface org.apache.accumulo.core.client.AccumuloClient.ClientFactory
Builds AccumuloClient or client Properties
build() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration.Builder
Build the clone configuration
build() - Method in interface org.apache.accumulo.core.client.admin.ImportConfiguration.Builder
Build the import table configuration
build() - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerOptions
 
build() - Method in interface org.apache.accumulo.core.client.rfile.RFile.WriterOptions
 
build() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration.Builder
 
build() - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
build() - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
build() - Method in class org.apache.accumulo.core.clientImpl.ImportConfigurationImpl
 
build() - Method in interface org.apache.accumulo.core.conf.SiteConfiguration.Buildable
 
build() - Method in interface org.apache.accumulo.core.data.KeyBuilder.Build
Build a Key from this builder.
build() - Method in interface org.apache.accumulo.core.data.LoadPlan.Builder
 
build() - Method in class org.apache.accumulo.core.file.FileOperations.IndexReaderBuilder
 
build() - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
Execute the operation, constructing the specified file reader.
build() - Method in class org.apache.accumulo.core.file.FileOperations.ScanReaderBuilder
Execute the operation, constructing a scan iterator.
build() - Method in class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
build() - Method in interface org.apache.accumulo.core.iteratorsImpl.IteratorBuilder.IteratorBuilderOptions
Finish building and return the completed IteratorBuilder.
build() - Method in class org.apache.accumulo.core.iteratorsImpl.IteratorBuilderImpl
 
build() - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
build() - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.Options
 
build() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatch.Builder
 
build() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlan.Builder
 
build() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch.Builder
 
build() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlanImpl.BuilderImpl
 
build() - Method in class org.apache.accumulo.core.util.threads.ThreadPools.ThreadPoolExecutorBuilder
 
buildClient(ClientContext.ClientBuilderImpl<AccumuloClient>) - Static method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
buildDocKey() - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
builder() - Static method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
 
builder() - Static method in interface org.apache.accumulo.core.client.admin.ImportConfiguration
 
builder() - Static method in class org.apache.accumulo.core.data.Key
Create a Key builder.
builder() - Static method in class org.apache.accumulo.core.data.LoadPlan
 
builder() - Static method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatch
 
builder() - Static method in interface org.apache.accumulo.core.spi.scan.ScanDispatch
 
builder() - Static method in class org.apache.accumulo.core.util.Retry
 
builder(boolean) - Static method in class org.apache.accumulo.core.data.Key
Create a Key builder.
builder(Class<? extends Summarizer>) - Static method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
 
builder(String) - Static method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
Call this method to initiate a chain of fluent method calls to a create an immutable SummarizerConfiguration
builder(Collection<IterInfo>) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorBuilder
Start building the iterator builder.
builder(AccumuloClient) - Static method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata
 
builder(Property, CacheType) - Static method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
BuilderImpl(CompactionKind, Set<CompactableFile>, Set<CompactableFile>) - Constructor for class org.apache.accumulo.core.util.compaction.CompactionPlanImpl.BuilderImpl
 
buildFollowingPartitionKey(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
buildKey(Text, Text) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
buildKey(Text, Text) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
buildKey(Text, Text, Text) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
buildKey(Text, Text, Text) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
buildMap() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
buildProps(ClientContext.ClientBuilderImpl<Properties>) - Static method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
Bulk - Class in org.apache.accumulo.core.clientImpl.bulk
 
Bulk() - Constructor for class org.apache.accumulo.core.clientImpl.bulk.Bulk
 
BULK_ARBITRATOR_TYPE - Static variable in class org.apache.accumulo.core.Constants
 
BULK_BAD_ERROR_DIRECTORY - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
BULK_BAD_INPUT_DIRECTORY - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
BULK_BAD_LOAD_MAPPING - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
BULK_CONCURRENT_MERGE - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
BULK_IMPORT - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
BULK_IMPORT - Enum constant in enum org.apache.accumulo.core.security.NamespacePermission
 
BULK_IMPORT - Enum constant in enum org.apache.accumulo.core.security.TablePermission
 
BULK_IMPORT_CLIENT_BULK_THREADS_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
BULK_IMPORT_CLIENT_LOAD_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
BULK_IMPORT_DIR_MOVE_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
BULK_IMPORTS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
BULK_IMPORTS - Enum constant in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
 
BULK_LOAD_MAPPING - Static variable in class org.apache.accumulo.core.Constants
 
BULK_LOAD_THREADS - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
BULK_LOAD_THREADS_DEFAULT - Static variable in interface org.apache.accumulo.core.client.admin.TableOperations.ImportMappingOptions
This is the default number of threads used to determine where to load files.
BULK_PREFIX - Static variable in class org.apache.accumulo.core.Constants
 
BULK_RENAME_FILE - Static variable in class org.apache.accumulo.core.Constants
 
Bulk.FileInfo - Class in org.apache.accumulo.core.clientImpl.bulk
WARNING : do not change this class, its used for serialization to Json
Bulk.Files - Class in org.apache.accumulo.core.clientImpl.bulk
 
Bulk.Mapping - Class in org.apache.accumulo.core.clientImpl.bulk
WARNING : do not change this class, its used for serialization to Json
Bulk.Tablet - Class in org.apache.accumulo.core.clientImpl.bulk
WARNING : do not change this class, its used for serialization to Json
BulkFileColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
bulkImport() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
 
bulkImport() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
 
bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean, AsyncMethodCallback<List<TKeyExtent>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean, AsyncMethodCallback<List<TKeyExtent>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
BulkImport - Class in org.apache.accumulo.core.clientImpl.bulk
 
BulkImport(String, ClientContext) - Constructor for class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
bulkImport_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
bulkImport_args(TabletClientService.bulkImport_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
Performs a deep copy on other.
bulkImport_args(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
bulkImport_call(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean, AsyncMethodCallback<List<TKeyExtent>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.bulkImport_call
 
bulkImport_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
bulkImport_result(List<TKeyExtent>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
bulkImport_result(TabletClientService.bulkImport_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
Performs a deep copy on other.
BulkImport.KeyExtentCache - Interface in org.apache.accumulo.core.clientImpl.bulk
 
bulkImported(KeyExtent, TabletFile) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
bulkImportFiles() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.bulkImportFiles
 
bulkImportFiles() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.bulkImportFiles
 
bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback<List<String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback<List<String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
bulkImportFiles_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
bulkImportFiles_args(ClientService.bulkImportFiles_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
Performs a deep copy on other.
bulkImportFiles_args(TInfo, TCredentials, long, String, List<String>, String, boolean) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
bulkImportFiles_call(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback<List<String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.bulkImportFiles_call
 
bulkImportFiles_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
bulkImportFiles_result(List<String>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
bulkImportFiles_result(ClientService.bulkImportFiles_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
Performs a deep copy on other.
bulkImports - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
bulkImports - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
BulkImportState - Enum in org.apache.accumulo.core.master.thrift
 
BulkImportStatus - Class in org.apache.accumulo.core.master.thrift
 
BulkImportStatus() - Constructor for class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
BulkImportStatus(long, String, BulkImportState) - Constructor for class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
BulkImportStatus(BulkImportStatus) - Constructor for class org.apache.accumulo.core.master.thrift.BulkImportStatus
Performs a deep copy on other.
BulkImportStatus._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.
bulks - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
BULKS - Enum constant in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
BulkSerialize - Class in org.apache.accumulo.core.clientImpl.bulk
Place for all bulk import serialization code.
BulkSerialize() - Constructor for class org.apache.accumulo.core.clientImpl.bulk.BulkSerialize
 
BulkSerialize.Input - Interface in org.apache.accumulo.core.clientImpl.bulk
 
BulkSerialize.Output - Interface in org.apache.accumulo.core.clientImpl.bulk
 
BUSY - Enum constant in enum org.apache.accumulo.core.spi.scan.ScanServerAttempt.Result
 
BUSY_TIMEOUT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args._Fields
 
BUSY_TIMEOUT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args._Fields
 
BUSY_TIMEOUT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
BUSY_TIMEOUT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
busyTimeout - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
busyTimeout - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
busyTimeout - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
busyTimeout - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
BYTE_BUFFER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Overhead for ByteBuffer
ByteArrayComparator - Class in org.apache.accumulo.core.util
 
ByteArrayComparator() - Constructor for class org.apache.accumulo.core.util.ByteArrayComparator
 
ByteArraySet - Class in org.apache.accumulo.core.util
 
ByteArraySet() - Constructor for class org.apache.accumulo.core.util.ByteArraySet
 
ByteArraySet(Collection<? extends byte[]>) - Constructor for class org.apache.accumulo.core.util.ByteArraySet
 
byteAt(int) - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
byteAt(int) - Method in class org.apache.accumulo.core.data.ByteSequence
Gets a byte within this sequence.
ByteBufferUtil - Class in org.apache.accumulo.core.util
 
ByteBufferUtil() - Constructor for class org.apache.accumulo.core.util.ByteBufferUtil
 
BYTES - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
ByteSequence - Class in org.apache.accumulo.core.data
A sequence of bytes.
ByteSequence() - Constructor for class org.apache.accumulo.core.data.ByteSequence
 
BytesLexicoder - Class in org.apache.accumulo.core.client.lexicoder
For each of the methods, this lexicoder just passes the input through untouched.
BytesLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
 
ByteUtils - Class in org.apache.accumulo.core.clientImpl.lexicoder
 
ByteUtils() - Constructor for class org.apache.accumulo.core.clientImpl.lexicoder.ByteUtils
 
Bzip2 - Class in org.apache.accumulo.core.spi.file.rfile.compression
 
Bzip2() - Constructor for class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 

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.CachableBuilder - Class in org.apache.accumulo.core.file.blockfile.impl
 
CachableBlockFile.CachedBlockRead - Class in org.apache.accumulo.core.file.blockfile.impl
 
CachableBlockFile.Reader - Class in org.apache.accumulo.core.file.blockfile.impl
Class wraps the BCFile reader.
CachableBuilder() - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
cache - Variable in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
cache - Variable in class org.apache.accumulo.core.iteratorsImpl.system.VisibilityFilter
 
CACHE_FIXED_OVERHEAD - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
cacheBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Cache the block with the specified name and buffer.
cacheBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
cacheBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
cacheBlock(String, byte[]) - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Add block to cache.
cacheBlock(String, byte[], boolean) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Cache the block with the specified name and buffer.
cacheCodecsWithNonDefaultSizes() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
cacheCodecsWithNonDefaultSizes() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
cacheCodecsWithNonDefaultSizes() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
cacheCodecsWithNonDefaultSizes() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
CachedBlock - Class in org.apache.accumulo.core.file.blockfile.cache.lru
Represents an entry in the configurable block cache.
CachedBlock(String, byte[], long, boolean) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
CachedBlock.BlockPriority - Enum in org.apache.accumulo.core.file.blockfile.cache.lru
 
CachedBlockQueue - Class in org.apache.accumulo.core.file.blockfile.cache.lru
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.lru.CachedBlockQueue
 
CachedBlockRead(InputStream) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
CachedBlockRead(CacheEntry, byte[]) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
CacheEntry - Interface in org.apache.accumulo.core.spi.cache
 
CacheEntry.Weighable - Interface in org.apache.accumulo.core.spi.cache
 
cacheProvider - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
cacheProvider(CacheProvider) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
CacheProvider - Interface in org.apache.accumulo.core.file.blockfile.impl
 
CacheStats() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
CacheType - Enum in org.apache.accumulo.core.spi.cache
 
calculateOverhead(long, long, int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
call(long, T) - Method in interface org.apache.accumulo.core.fate.Repo
 
callbackHandler - Variable in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
CAN_CLONE_TABLE - Static variable in class org.apache.accumulo.core.util.Validators
 
CAN_CREATE_TABLES - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.OutputConfigurator.Features
 
cancel() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.cancel
 
cancel() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.cancel
 
cancel() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.cancel
 
cancel() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.cancel
 
cancel(boolean) - Method in class org.apache.accumulo.core.util.CancelFlagFuture
 
cancel(long) - Method in class org.apache.accumulo.core.fate.Fate
Attempts to cancel a running Fate transaction
cancel(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
cancel(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
cancel(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
cancel(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.Iface
 
cancel(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
cancel(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
cancel(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient
 
cancel(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncIface
 
cancel_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
cancel_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
cancel_args(CompactionCoordinatorService.cancel_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
Performs a deep copy on other.
cancel_args(CompactorService.cancel_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
Performs a deep copy on other.
cancel_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
cancel_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
cancel_call(TInfo, TCredentials, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.cancel_call
 
cancel_call(TInfo, TCredentials, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.cancel_call
 
cancel_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
cancel_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
cancel_result(CompactionCoordinatorService.cancel_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
Performs a deep copy on other.
cancel_result(CompactorService.cancel_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
Performs a deep copy on other.
cancelCompaction(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
cancelCompaction(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
cancelCompaction(ClientContext, HostAndPort, String) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
cancelFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.cancelFateOperation
 
cancelFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Processor.cancelFateOperation
 
cancelFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
cancelFateOperation(TInfo, TCredentials, long) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.Iface
 
cancelFateOperation(TInfo, TCredentials, long, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient
 
cancelFateOperation(TInfo, TCredentials, long, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.AsyncIface
 
cancelFateOperation_args() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
cancelFateOperation_args(FateService.cancelFateOperation_args) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
Performs a deep copy on other.
cancelFateOperation_args(TInfo, TCredentials, long) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
cancelFateOperation_call(TInfo, TCredentials, long, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.cancelFateOperation_call
 
cancelFateOperation_result() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
cancelFateOperation_result(boolean, ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
cancelFateOperation_result(FateService.cancelFateOperation_result) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
Performs a deep copy on other.
CancelFlagFuture<T> - Class in org.apache.accumulo.core.util
A simple future wrapper that will set an atomic boolean to true if a future is successfully canceled
CancelFlagFuture(Future<T>, AtomicBoolean) - Constructor for class org.apache.accumulo.core.util.CancelFlagFuture
 
CANCELLED - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TCompactionState
 
cancelUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.cancelUpdate
 
cancelUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.cancelUpdate
 
cancelUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
cancelUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
cancelUpdate(TInfo, long, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
cancelUpdate(TInfo, long, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
cancelUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
cancelUpdate_args(TabletClientService.cancelUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
Performs a deep copy on other.
cancelUpdate_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
cancelUpdate_call(TInfo, long, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.cancelUpdate_call
 
cancelUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
cancelUpdate_result(boolean) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
cancelUpdate_result(TabletClientService.cancelUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
Performs a deep copy on other.
canCreateTables(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.OutputConfigurator
Determines whether tables are permitted to be created as needed.
canCreateTables(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
Determines whether tables are permitted to be created as needed.
canCreateTables(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
Determines whether tables are permitted to be created as needed.
candidates - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
CANDIDATES - Enum constant in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
CANNOT_AUTHENTICATE - Enum constant in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
 
CANNOT_AUTHENTICATE - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorErrorCode
 
CANNOT_INSTANTIATE_REPLAYER - Enum constant in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
 
canonical() - Method in class org.apache.accumulo.core.data.AbstractId
The canonical ID.
canRetry() - Method in class org.apache.accumulo.core.util.Retry
 
canSee(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates whether or not the user is able to see key.
canSeeColumnFamily(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates whether or not key can be seen, according to the fetched column families for this iterator.
cf - Variable in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
CF - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
CfCqSliceFilter - Class in org.apache.accumulo.core.iterators.user
Filters key/value pairs for a range of column families and a range of column qualifiers.
CfCqSliceFilter() - Constructor for class org.apache.accumulo.core.iterators.user.CfCqSliceFilter
 
CfCqSliceOpts - Class in org.apache.accumulo.core.iterators.user
 
CfCqSliceOpts(Map<String, String>) - Constructor for class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
CfCqSliceOpts(CfCqSliceOpts) - Constructor for class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
CfCqSliceSeekingFilter - Class in org.apache.accumulo.core.iterators.user
Filters key/value pairs for a range of column families and a range of column qualifiers.
CfCqSliceSeekingFilter() - Constructor for class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
 
cfg - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
CFG - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
 
changeAuthorizations() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
changeAuthorizations() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeAuthorizations
 
changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
changeAuthorizations_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
changeAuthorizations_args(ClientService.changeAuthorizations_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
Performs a deep copy on other.
changeAuthorizations_args(TInfo, TCredentials, String, List<ByteBuffer>) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
changeAuthorizations_call(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.changeAuthorizations_call
 
changeAuthorizations_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
changeAuthorizations_result(ClientService.changeAuthorizations_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
Performs a deep copy on other.
changeAuthorizations_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
changeLocalUserPassword() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
changeLocalUserPassword() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeLocalUserPassword
 
changeLocalUserPassword(String, PasswordToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Set the user's password
changeLocalUserPassword(String, PasswordToken) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
changeLocalUserPassword_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
changeLocalUserPassword_args(ClientService.changeLocalUserPassword_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
Performs a deep copy on other.
changeLocalUserPassword_args(TInfo, TCredentials, String, ByteBuffer) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
changeLocalUserPassword_call(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
 
changeLocalUserPassword_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
changeLocalUserPassword_result(ClientService.changeLocalUserPassword_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
Performs a deep copy on other.
changeLocalUserPassword_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
changeUserAuthorizations(String, Authorizations) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Set the user's record-level authorizations
changeUserAuthorizations(String, Authorizations) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
check(Constraint.Environment, Mutation) - Method in interface org.apache.accumulo.core.constraints.Constraint
Deprecated.
Checks a mutation for constraint violations.
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
Deprecated.
 
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.constraints.NoDeleteConstraint
Deprecated.
 
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.constraints.VisibilityConstraint
Deprecated.
 
check(Constraint.Environment, Mutation) - Method in interface org.apache.accumulo.core.constraints.Constraint
Deprecated.
Implemented for backwards compatibility.
check(Constraint.Environment, Mutation) - Method in interface org.apache.accumulo.core.data.constraints.Constraint
Checks a mutation for constraint violations.
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.data.constraints.DefaultKeySizeConstraint
 
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.data.constraints.NoDeleteConstraint
 
check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.data.constraints.VisibilityConstraint
 
checkClass() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkClass
 
checkClass() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkClass
 
checkClass(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
checkClass(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
checkClass(TInfo, TCredentials, String, String, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
checkClass(TInfo, TCredentials, String, String, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
checkClass_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
checkClass_args(ClientService.checkClass_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
Performs a deep copy on other.
checkClass_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
checkClass_call(TInfo, TCredentials, String, String, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkClass_call
 
checkClass_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
checkClass_result(boolean) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
checkClass_result(ClientService.checkClass_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
Performs a deep copy on other.
checkConsistency() - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
checkConsistency() - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.Options
Checks that the metadata table forms a linked list and automatically backs up until it does.
checkGlobalLock(ZooReaderWriter, ServiceLock.ServiceLockPath) - Method in class org.apache.accumulo.core.fate.AdminUtil
 
checkIOExceptionCause(IOException) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
 
checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.
checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.
checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
checkIteratorConflicts(Map<String, String>, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Static method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
checkLocalityGroups(Map<String, String>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
checkNamespaceClass() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
checkNamespaceClass() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkNamespaceClass
 
checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
checkNamespaceClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
checkNamespaceClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
checkNamespaceClass_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
checkNamespaceClass_args(ClientService.checkNamespaceClass_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
Performs a deep copy on other.
checkNamespaceClass_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
checkNamespaceClass_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
 
checkNamespaceClass_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
checkNamespaceClass_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
checkNamespaceClass_result(ClientService.checkNamespaceClass_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
Performs a deep copy on other.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
 
checkOutputSpecs(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
 
checkReadBytesAvailable(long) - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
checkState(boolean) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
checkTableClass() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkTableClass
 
checkTableClass() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkTableClass
 
checkTableClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
checkTableClass(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
checkTableClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
checkTableClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
checkTableClass_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
checkTableClass_args(ClientService.checkTableClass_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
Performs a deep copy on other.
checkTableClass_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
checkTableClass_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkTableClass_call
 
checkTableClass_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
checkTableClass_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
checkTableClass_result(ClientService.checkTableClass_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
Performs a deep copy on other.
choosable(VolumeChooserEnvironment, Set<String>) - Method in class org.apache.accumulo.core.spi.fs.DelegatingChooser
 
choosable(VolumeChooserEnvironment, Set<String>) - Method in class org.apache.accumulo.core.spi.fs.PreferredVolumeChooser
Returns the subset of volumes that match the defined preferred volumes value
choosable(VolumeChooserEnvironment, Set<String>) - Method in class org.apache.accumulo.core.spi.fs.RandomVolumeChooser
 
choosable(VolumeChooserEnvironment, Set<String>) - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooser
Return the subset of all possible volumes that could be chosen across all invocations of VolumeChooser.choose(VolumeChooserEnvironment, Set).
This is currently used to determine if the chosen volumes can support the required filesystem operations for write ahead logs.
There may be other use cases in the future.
choose(VolumeChooserEnvironment, Set<String>) - Method in class org.apache.accumulo.core.spi.fs.DelegatingChooser
 
choose(VolumeChooserEnvironment, Set<String>) - Method in class org.apache.accumulo.core.spi.fs.PreferredVolumeChooser
 
choose(VolumeChooserEnvironment, Set<String>) - Method in class org.apache.accumulo.core.spi.fs.RandomVolumeChooser
Selects a volume at random from the provided set of volumes.
choose(VolumeChooserEnvironment, Set<String>) - Method in class org.apache.accumulo.core.spi.fs.SpaceAwareVolumeChooser
 
choose(VolumeChooserEnvironment, Set<String>) - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooser
Choose a volume from the provided options.
chop() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
 
chop() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
 
chop(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
chop(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
chop(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
chop(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
CHOP - Enum constant in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
Compaction initiated by merge operation
CHOP - Enum constant in enum org.apache.accumulo.core.spi.compaction.CompactionKind
A compaction executed prior to merging tablets.
CHOP - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionKind
 
CHOP - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
 
chop_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
chop_args(TabletClientService.chop_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
Performs a deep copy on other.
chop_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
chop_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.chop_call
 
chopped - Variable in class org.apache.accumulo.core.metadata.TabletLocationState
 
CHOPPED - Enum constant in enum org.apache.accumulo.core.manager.thrift.TabletLoadState
 
CHOPPED - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
CHOPPED_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ChoppedColumnFamily
 
ChoppedColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ChoppedColumnFamily
 
CLASS - Static variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
 
CLASS - Static variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
 
CLASS_LOADER_CONTEXT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
CLASS_LOADER_CONTEXT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
 
CLASS_LOADER_CONTEXT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
CLASS_LOADER_CONTEXT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
CLASS_NAME - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
 
CLASS_NAME - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
CLASS_NAME - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
CLASS_NAME - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
 
CLASS_NAME - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
 
CLASS_NAME - Static variable in class org.apache.accumulo.core.client.security.tokens.KerberosToken
 
CLASS_PREFIX - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
CLASSLOADER_CONTEXT - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.ScanOpts
 
classLoaderContext - Variable in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
classLoaderContext - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
classLoaderContext - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
classLoaderContext - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
classLoaderContext - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
ClassLoaderUtil - Class in org.apache.accumulo.core.classloader
 
classname - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
className - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
className - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
className - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
className - Variable in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
className - Variable in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
CLASSNAME - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
CLASSNAME - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
 
CLASSNAMELIST - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
ClassSize - Class in org.apache.accumulo.core.file.blockfile.cache.impl
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.impl.ClassSize
 
CLEAN_STOP - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerGoalState
 
CLEANER - Static variable in class org.apache.accumulo.core.util.cleaner.CleanerUtil
 
CleanerUtil - Class in org.apache.accumulo.core.util.cleaner
This class collects all the cleaner actions executed in various parts of the code.
CleanerUtil() - Constructor for class org.apache.accumulo.core.util.cleaner.CleanerUtil
 
CleanUp - Class in org.apache.accumulo.core.util
Deprecated.
since 2.0.0 Use only AccumuloClient instead. Also, make sure you close the AccumuloClient instances.
CleanUp() - Constructor for class org.apache.accumulo.core.util.CleanUp
Deprecated.
 
CLEANUP - Enum constant in enum org.apache.accumulo.core.master.thrift.BulkImportState
 
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.client.security.tokens.AuthenticationToken.Properties
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
clear() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
clear() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
clear() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
clear() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
clear() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
clear() - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
clear() - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
clear() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
clear() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Clears this cache.
clear() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
clear() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
clear() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
clear() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
clear() - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
clear() - Method in exception org.apache.accumulo.core.manager.thrift.RecoveryException
 
clear() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
clear() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
clear() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
clear() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
clear() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
clear() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
clear() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
clear() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
clear() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
clear() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
clear() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
clear() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
clear() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
clear() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
clear() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
clear() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
clear() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
clear() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
clear() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
clear() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
clear() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
clear() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
clear() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
clear() - Method in class org.apache.accumulo.core.util.Stat
 
clear(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Clears this cache of all information about nodes rooted at the given path.
clearClassLoaderContext() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Clears the current classloader context set on this scanner
clearClassLoaderContext() - Method in interface org.apache.accumulo.core.client.ScannerBase
Clears the current classloader context set on this scanner
clearClassLoaderContext() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
clearColumns() - Method in interface org.apache.accumulo.core.client.ScannerBase
Clears the columns to be fetched (useful for resetting the scanner for reuse).
clearColumns() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
clearIteratorSamplerConfiguration() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
Clear any iterator sampler configuration.
clearLocatorCache(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Clears the tablet locator cache for a specified table
clearLocatorCache(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
clearLocators() - Static method in class org.apache.accumulo.core.clientImpl.TabletLocator
 
clearOptions() - Method in class org.apache.accumulo.core.client.IteratorSetting
Remove all options from the iterator.
clearProblemReportTimes() - Method in class org.apache.accumulo.core.spi.balancer.util.ThrottledBalancerProblemReporter
Clears reported problems so that a problem report will be logged immediately the next time ThrottledBalancerProblemReporter.reportProblem(Problem) is invoked.
clearSamplerConfiguration() - Method in interface org.apache.accumulo.core.client.ScannerBase
Clears sampler configuration making a scanner read all data.
clearSamplerConfiguration() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
clearSamplerConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Clear all sampling configuration properties on the table.
clearSamplerConfiguration(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
clearScanIterators() - Method in interface org.apache.accumulo.core.client.ScannerBase
Clears scan iterators prior to returning a scanner to the pool.
clearScanIterators() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
clearTableListCache() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
clearTableListCache() - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
client - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
client(Class<?>, RangeInputSplit, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
 
client(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
Client(TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client
 
CLIENT - Enum constant in enum org.apache.accumulo.core.singletons.SingletonManager.Mode
In this mode singletons are disabled when the number of active client reservations goes to zero.
CLIENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
CLIENT - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
CLIENT_CONFIG - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase.InstanceOpts
 
ClientBuilderImpl(Function<ClientContext.ClientBuilderImpl<T>, T>) - Constructor for class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
ClientConfConverter - Class in org.apache.accumulo.core.clientImpl
 
ClientConfConverter() - Constructor for class org.apache.accumulo.core.clientImpl.ClientConfConverter
 
ClientConfigGenerate - Class in org.apache.accumulo.core.conf
Generates client-properties.md for documentation on Accumulo website and accumulo-client.properties for Accumulo distribution tarball
ClientConfiguration - Class in org.apache.accumulo.core.client
Deprecated.
since 2.0.0, replaced by Accumulo.newClient()
ClientConfiguration.ClientProperty - Enum in org.apache.accumulo.core.client
Deprecated.
 
ClientContext - Class in org.apache.accumulo.core.clientImpl
This class represents any essential configuration and credentials needed to initiate RPC operations throughout the code.
ClientContext(SingletonReservation, ClientInfo, AccumuloConfiguration, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.accumulo.core.clientImpl.ClientContext
Create a client context with the provided configuration.
ClientContext.ClientBuilderImpl<T> - Class in org.apache.accumulo.core.clientImpl
 
ClientInfo - Interface in org.apache.accumulo.core.clientImpl
Accumulo client information.
ClientInfoImpl - Class in org.apache.accumulo.core.clientImpl
 
ClientInfoImpl(URL) - Constructor for class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
ClientInfoImpl(Path) - Constructor for class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
ClientInfoImpl(Properties) - Constructor for class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
ClientInfoImpl(Properties, AuthenticationToken) - Constructor for class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
ClientOpts - Class in org.apache.accumulo.core.cli
 
ClientOpts() - Constructor for class org.apache.accumulo.core.cli.ClientOpts
 
ClientOpts.AuthConverter - Class in org.apache.accumulo.core.cli
 
ClientOpts.NullSplitter - Class in org.apache.accumulo.core.cli
 
ClientOpts.PasswordConverter - Class in org.apache.accumulo.core.cli
 
ClientOpts.VisibilityConverter - Class in org.apache.accumulo.core.cli
 
ClientProperty - Enum in org.apache.accumulo.core.conf
 
ClientService - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService
 
ClientService.AsyncClient - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.authenticate_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.authenticateUser_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.bulkImportFiles_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.changeAuthorizations_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.changeLocalUserPassword_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.checkClass_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.checkNamespaceClass_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.checkTableClass_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.createLocalUser_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.dropLocalUser_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getConfiguration_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getDiskUsage_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getInstanceId_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getNamespaceConfiguration_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getNamespaceProperties_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getRootTabletLocation_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getSystemProperties_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getTableConfiguration_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getTableProperties_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getUserAuthorizations_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getVersionedNamespaceProperties_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getVersionedSystemProperties_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getVersionedTableProperties_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.getZooKeepers_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.grantNamespacePermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.grantSystemPermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.grantTablePermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.hasNamespacePermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.hasSystemPermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.hasTablePermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.isActive_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.listLocalUsers_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.ping_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.revokeNamespacePermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.revokeSystemPermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncClient.revokeTablePermission_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncIface - Interface in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.authenticate<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.authenticateUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.bulkImportFiles<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.changeAuthorizations<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.changeLocalUserPassword<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.checkClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.checkNamespaceClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.checkTableClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.createLocalUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.dropLocalUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getDiskUsage<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getInstanceId<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getNamespaceConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getNamespaceProperties<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getRootTabletLocation<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getSystemProperties<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getTableConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getTableProperties<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getUserAuthorizations<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getVersionedNamespaceProperties<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getVersionedSystemProperties<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getVersionedTableProperties<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.getZooKeepers<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.grantNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.grantSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.grantTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.hasNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.hasSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.hasTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.isActive<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.listLocalUsers<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.ping<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.revokeNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.revokeSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.AsyncProcessor.revokeTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.authenticate_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.authenticate_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.authenticate_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.authenticate_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.authenticateUser_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.authenticateUser_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.authenticateUser_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.bulkImportFiles_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.bulkImportFiles_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.bulkImportFiles_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.bulkImportFiles_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.changeAuthorizations_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.changeAuthorizations_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.changeLocalUserPassword_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.changeLocalUserPassword_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.changeLocalUserPassword_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.changeLocalUserPassword_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkClass_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.checkClass_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkClass_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.checkClass_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkNamespaceClass_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.checkNamespaceClass_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkNamespaceClass_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.checkNamespaceClass_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkTableClass_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.checkTableClass_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.checkTableClass_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.checkTableClass_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.Client.Factory - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.createLocalUser_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.createLocalUser_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.createLocalUser_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.createLocalUser_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.dropLocalUser_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.dropLocalUser_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.dropLocalUser_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.dropLocalUser_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getConfiguration_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getConfiguration_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getConfiguration_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getConfiguration_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getDiskUsage_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getDiskUsage_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getDiskUsage_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getDiskUsage_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.getInstanceId_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.getInstanceId_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getNamespaceConfiguration_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getNamespaceConfiguration_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getNamespaceConfiguration_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getNamespaceConfiguration_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getNamespaceProperties_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getNamespaceProperties_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getNamespaceProperties_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getNamespaceProperties_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.getRootTabletLocation_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.getRootTabletLocation_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getSystemProperties_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getSystemProperties_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getSystemProperties_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getSystemProperties_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getTableConfiguration_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getTableConfiguration_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getTableConfiguration_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getTableConfiguration_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getTableProperties_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getTableProperties_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getTableProperties_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getTableProperties_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.getUserAuthorizations_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.getUserAuthorizations_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getVersionedNamespaceProperties_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getVersionedNamespaceProperties_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getVersionedNamespaceProperties_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getVersionedNamespaceProperties_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getVersionedSystemProperties_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getVersionedSystemProperties_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getVersionedSystemProperties_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getVersionedSystemProperties_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getVersionedTableProperties_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getVersionedTableProperties_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.getVersionedTableProperties_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.getVersionedTableProperties_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.getZooKeepers_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.getZooKeepers_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.grantNamespacePermission_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.grantNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.grantNamespacePermission_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.grantNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.grantSystemPermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.grantSystemPermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.grantTablePermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.grantTablePermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.hasNamespacePermission_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.hasNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.hasNamespacePermission_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.hasNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.hasSystemPermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.hasSystemPermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.hasTablePermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.hasTablePermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.isActive_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.isActive_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.isActive_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.isActive_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.listLocalUsers_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.listLocalUsers_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.listLocalUsers_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.listLocalUsers_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.ping_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.ping_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.Processor<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.authenticate<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.authenticateUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.bulkImportFiles<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.changeAuthorizations<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.changeLocalUserPassword<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.checkClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.checkNamespaceClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.checkTableClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.createLocalUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.dropLocalUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getDiskUsage<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getInstanceId<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getNamespaceConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getNamespaceProperties<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getRootTabletLocation<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getSystemProperties<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getTableConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getTableProperties<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getUserAuthorizations<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getVersionedNamespaceProperties<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getVersionedSystemProperties<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getVersionedTableProperties<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.getZooKeepers<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.grantNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.grantSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.grantTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.hasNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.hasSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.hasTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.isActive<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.listLocalUsers<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.ping<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.revokeNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.revokeSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.Processor.revokeTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.revokeNamespacePermission_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.revokeNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.revokeNamespacePermission_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.revokeNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientService.revokeSystemPermission_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ClientService.revokeSystemPermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.revokeSystemPermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.revokeTablePermission_args._Fields - Enum in org.apache.accumulo.core.clientImpl.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.clientImpl.thrift
 
ClientService.revokeTablePermission_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClientServiceEnvironmentImpl - Class in org.apache.accumulo.core.clientImpl
 
ClientServiceEnvironmentImpl(ClientContext) - Constructor for class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
ClientServiceThriftClient - Class in org.apache.accumulo.core.rpc.clients
 
ClientSideIteratorScanner - Class in org.apache.accumulo.core.client
A scanner that instantiates iterators on the client side instead of on the tablet server.
ClientSideIteratorScanner(Scanner) - Constructor for class org.apache.accumulo.core.client.ClientSideIteratorScanner
Constructs a scanner that can execute client-side iterators.
clip(Range) - Method in class org.apache.accumulo.core.data.Range
Creates a range which represents the intersection of this range and the passed in range.
clip(Range, boolean) - Method in class org.apache.accumulo.core.data.Range
Creates a range which represents the intersection of this range and the passed in range.
clone() - Method in interface org.apache.accumulo.core.client.security.tokens.AuthenticationToken
 
clone() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
clone() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
 
clone() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
clone() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
clone() - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
clone() - Method in class org.apache.accumulo.core.clientImpl.mapreduce.DelegationTokenStub
Deprecated.
 
clone() - Method in class org.apache.accumulo.core.data.Key
 
clone(String, String, boolean, Map<String, String>, Set<String>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Clone a table from an existing table.
clone(String, String, boolean, Map<String, String>, Set<String>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
clone(String, String, CloneConfiguration) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Clone a table from an existing table.
clone(String, String, CloneConfiguration) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
CLONE - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
CLONE_PREFIX - Static variable in class org.apache.accumulo.core.Constants
 
CLONE_PREFIX_BYTES - Static variable in class org.apache.accumulo.core.Constants
 
CloneConfiguration - Interface in org.apache.accumulo.core.client.admin
A configuration object that can be used with the table clone command in the TableOperations.
CloneConfiguration.Builder - Interface in org.apache.accumulo.core.client.admin
A CloneConfiguration builder
CloneConfigurationImpl - Class in org.apache.accumulo.core.clientImpl
A CloneConfiguration implementation which also implements the builder thereof
CloneConfigurationImpl() - Constructor for class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
CLONED - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
ClonedColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ClonedColumnFamily
 
cloneWithSamplingEnabled() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Returns a new iterator environment object that can be used to create deep copies over sample data.
close() - Method in interface org.apache.accumulo.core.client.AccumuloClient
Cleans up any resources created by an AccumuloClient like threads and sockets.
close() - Method in interface org.apache.accumulo.core.client.BatchDeleter
 
close() - Method in interface org.apache.accumulo.core.client.BatchScanner
 
close() - Method in interface org.apache.accumulo.core.client.BatchWriter
Flush and release any resources.
close() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
close() - Method in interface org.apache.accumulo.core.client.ConditionalWriter
release any resources (like threads pools) used by conditional writer
close() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
close() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
close() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
close() - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
Flush and release all resources.
close() - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
 
close() - Method in interface org.apache.accumulo.core.client.ScannerBase
Closes any underlying connections on the scanner.
close() - Method in class org.apache.accumulo.core.clientImpl.BatchWriterImpl
 
close() - Method in class org.apache.accumulo.core.clientImpl.bulk.LoadMappingIterator
 
close() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
close() - Method in class org.apache.accumulo.core.clientImpl.ConditionalWriterImpl
 
close() - Method in class org.apache.accumulo.core.clientImpl.MultiTableBatchWriterImpl
 
close() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
close() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
close() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReader
 
close() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchWriter
 
close() - Method in class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
close() - Method in class org.apache.accumulo.core.crypto.streams.BlockedOutputStream
 
close() - Method in class org.apache.accumulo.core.crypto.streams.DiscardCloseOutputStream
 
close() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
 
close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
close() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
close() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
close() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
close() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Finishing reading the block.
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Finishing reading the BCFile.
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
Signaling the end of write to the block.
close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Close the BCFile Writer.
close() - 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.file.streams.BoundedRangeFileInputStream
 
close() - Method in class org.apache.accumulo.core.file.streams.RateLimitedOutputStream
 
close() - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
close() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
close() - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletsMutator
 
close() - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata
 
close() - Method in interface org.apache.accumulo.core.metrics.MetricsInfo
Close the underlying registry and release resources.
close() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
close() - Method in class org.apache.accumulo.core.singletons.SingletonReservation
 
close() - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
close() - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
close(boolean) - Method in interface org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator.DataSource
 
close(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
 
close(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Writer
 
close(Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
Deprecated.
 
close(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
Deprecated.
 
close(TServiceClient, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
 
CLOSE - Enum constant in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
Compaction initiated to close a unload a tablet
CLOSE - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
 
closeConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
 
closeConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
 
closeConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
closeConditionalUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
closeConditionalUpdate(TInfo, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
closeConditionalUpdate(TInfo, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
closeConditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
closeConditionalUpdate_args(TabletClientService.closeConditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
Performs a deep copy on other.
closeConditionalUpdate_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
closeConditionalUpdate_call(TInfo, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeConditionalUpdate_call
 
CLOSED - Enum constant in enum org.apache.accumulo.core.singletons.SingletonManager.Mode
In this mode singletons are permanently disabled and entering this mode prevents transitioning to other modes.
closeDeepCopies() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
closeDeepCopies() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
closeDeepCopies() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
closeDeepCopies() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
closeDeepCopies() - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
closeDeepCopies() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
closeMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.closeMultiScan
 
closeMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.closeMultiScan
 
closeMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client
 
closeMultiScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Iface
 
closeMultiScan(TInfo, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient
 
closeMultiScan(TInfo, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncIface
 
closeMultiScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
closeMultiScan_args(TabletScanClientService.closeMultiScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
Performs a deep copy on other.
closeMultiScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
closeMultiScan_call(TInfo, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.closeMultiScan_call
 
closeMultiScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
closeMultiScan_result(NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
closeMultiScan_result(TabletScanClientService.closeMultiScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
Performs a deep copy on other.
closeScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.closeScan
 
closeScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.closeScan
 
closeScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client
 
closeScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Iface
 
closeScan(TInfo, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient
 
closeScan(TInfo, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncIface
 
closeScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
closeScan_args(TabletScanClientService.closeScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
Performs a deep copy on other.
closeScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
closeScan_call(TInfo, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.closeScan_call
 
closeUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
 
closeUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
 
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
 
closeUpdate(TInfo, long, AsyncMethodCallback<UpdateErrors>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
closeUpdate(TInfo, long, AsyncMethodCallback<UpdateErrors>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
closeUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
closeUpdate_args(TabletClientService.closeUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
Performs a deep copy on other.
closeUpdate_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
closeUpdate_call(TInfo, long, AsyncMethodCallback<UpdateErrors>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeUpdate_call
 
closeUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
closeUpdate_result(UpdateErrors, NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
closeUpdate_result(TabletClientService.closeUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
Performs a deep copy on other.
ClusterConfigParser - Class in org.apache.accumulo.core.conf.cluster
 
ClusterConfigParser() - Constructor for class org.apache.accumulo.core.conf.cluster.ClusterConfigParser
 
cmid - Variable in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
CMID - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
 
code - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
code - Variable in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
code - Variable in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
CODE - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
 
CODE - Enum constant in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
 
CODE - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
 
COL_FAMILY - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
COL_QUALIFIER - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
COL_VISIBILITY - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
COLF - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
 
COLF_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
colFamily - Variable in class org.apache.accumulo.core.data.Key
 
colFamily - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
colFamSet - Variable in class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
collector(SummarizerConfiguration) - Method in class org.apache.accumulo.core.client.summary.CountingSummarizer
 
collector(SummarizerConfiguration) - Method in interface org.apache.accumulo.core.client.summary.Summarizer
Factory method that creates a Summarizer.Collector based on configuration.
collector(SummarizerConfiguration) - Method in class org.apache.accumulo.core.client.summary.summarizers.DeletesSummarizer
 
collector(SummarizerConfiguration) - Method in class org.apache.accumulo.core.client.summary.summarizers.EntryLengthSummarizer
 
COLQ_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
colQualifier - Variable in class org.apache.accumulo.core.data.Key
 
colQualifier - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
Column - Class in org.apache.accumulo.core.data
A column, specified by family, qualifier, and visibility.
Column() - Constructor for class org.apache.accumulo.core.data.Column
Creates a new blank column.
Column(byte[], byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Column
Creates a new column.
Column(String) - Constructor for class org.apache.accumulo.core.client.IteratorSetting.Column
 
Column(String, String) - Constructor for class org.apache.accumulo.core.client.IteratorSetting.Column
 
Column(TColumn) - Constructor for class org.apache.accumulo.core.data.Column
Creates a new column.
Column(Text) - Constructor for class org.apache.accumulo.core.client.IteratorSetting.Column
 
Column(Text, Text) - Constructor for class org.apache.accumulo.core.client.IteratorSetting.Column
 
COLUMN_FAMILY - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
 
COLUMN_QUALIFIER - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
 
COLUMN_VISIBILITY - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
 
ColumnAgeOffFilter - Class in org.apache.accumulo.core.iterators.user
A filter that ages off key/value pairs based on the Key's column and timestamp.
ColumnAgeOffFilter() - Constructor for class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
ColumnAgeOffFilter.TTLSet - Class in org.apache.accumulo.core.iterators.user
 
columnFamilies - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
columnFamilies - Variable in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroup
 
columnFamily - Variable in class org.apache.accumulo.core.data.Column
 
columnFamily - Variable in class org.apache.accumulo.core.dataImpl.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.iteratorsImpl.system
 
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>, Set<ByteSequence>, boolean) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
ColumnFQ - Class in org.apache.accumulo.core.util
 
ColumnFQ(ColumnUpdate) - Constructor for class org.apache.accumulo.core.util.ColumnFQ
 
ColumnFQ(Key) - Constructor for class org.apache.accumulo.core.util.ColumnFQ
 
ColumnFQ(Text, Text) - 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.dataImpl.thrift.TColumn
 
ColumnQualifierFilter - Class in org.apache.accumulo.core.iteratorsImpl.system
 
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.TabletScanClientService.startMultiScan_args
 
columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
COLUMNS - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.ScanOpts
 
COLUMNS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
COLUMNS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
COLUMNS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
COLUMNS_KEY - Static variable in class org.apache.accumulo.core.iterators.OrIterator
 
COLUMNS_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
 
ColumnSet - Class in org.apache.accumulo.core.iteratorsImpl.conf
 
ColumnSet() - Constructor for class org.apache.accumulo.core.iteratorsImpl.conf.ColumnSet
 
ColumnSet(Collection<String>) - Constructor for class org.apache.accumulo.core.iteratorsImpl.conf.ColumnSet
 
ColumnSliceFilter - Class in org.apache.accumulo.core.iterators.user
 
ColumnSliceFilter() - Constructor for class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
ColumnToClassMapping<K> - Class in org.apache.accumulo.core.iteratorsImpl.conf
 
ColumnToClassMapping() - Constructor for class org.apache.accumulo.core.iteratorsImpl.conf.ColumnToClassMapping
 
ColumnToClassMapping(Map<String, String>, Class<? extends K>) - Constructor for class org.apache.accumulo.core.iteratorsImpl.conf.ColumnToClassMapping
 
ColumnToClassMapping(Map<String, String>, Class<? extends K>, String) - Constructor for class org.apache.accumulo.core.iteratorsImpl.conf.ColumnToClassMapping
 
ColumnUpdate - Class in org.apache.accumulo.core.data
A single column and value pair within a Mutation.
ColumnUpdate(byte[], byte[], byte[], boolean, long, boolean, byte[]) - Constructor for class org.apache.accumulo.core.data.ColumnUpdate
Creates a new column update.
ColumnUtil - Class in org.apache.accumulo.core.iteratorsImpl.conf
 
ColumnUtil() - Constructor for class org.apache.accumulo.core.iteratorsImpl.conf.ColumnUtil
 
ColumnUtil.ColFamHashKey - Class in org.apache.accumulo.core.iteratorsImpl.conf
 
ColumnUtil.ColHashKey - Class in org.apache.accumulo.core.iteratorsImpl.conf
 
columnVisibility - Variable in class org.apache.accumulo.core.data.Column
 
columnVisibility - Variable in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
ColumnVisibility - Class in org.apache.accumulo.core.security
Validate the column visibility is a valid expression and set the visibility for a Mutation.
ColumnVisibility() - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Creates an empty visibility.
ColumnVisibility(byte[]) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Creates a column visibility for a Mutation from a string already encoded in UTF-8 bytes.
ColumnVisibility(String) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Creates a column visibility for a Mutation.
ColumnVisibility(Text) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
Creates a column visibility for a Mutation.
ColumnVisibility.Node - Class in org.apache.accumulo.core.security
A node in the parse tree for a visibility expression.
ColumnVisibility.NodeComparator - Class in org.apache.accumulo.core.security
A node comparator.
ColumnVisibility.NodeType - Enum in org.apache.accumulo.core.security
The node types in a parse tree for a visibility expression.
colVisibility - Variable in class org.apache.accumulo.core.data.Key
 
colVisibility - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
combiner(SummarizerConfiguration) - Method in class org.apache.accumulo.core.client.summary.CountingSummarizer
 
combiner(SummarizerConfiguration) - Method in interface org.apache.accumulo.core.client.summary.Summarizer
Factory method that creates a Summarizer.Combiner.
combiner(SummarizerConfiguration) - Method in class org.apache.accumulo.core.client.summary.summarizers.DeletesSummarizer
 
combiner(SummarizerConfiguration) - Method in class org.apache.accumulo.core.client.summary.summarizers.EntryLengthSummarizer
 
Combiner - Class in org.apache.accumulo.core.iterators
A SortedKeyValueIterator that combines the Values for different versions (timestamp) of a Key within a row into a single Value.
Combiner() - Constructor for class org.apache.accumulo.core.iterators.Combiner
 
COMBINER_NAME - Static variable in class org.apache.accumulo.core.replication.ReplicationTable
Deprecated.
 
Combiner.ValueIterator - Class in org.apache.accumulo.core.iterators
A Java Iterator that iterates over the Values for a given Key from a source SortedKeyValueIterator.
compact() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
 
compact() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
 
compact(String, CompactionConfig) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Starts a full major compaction of the tablets in the range (start, end].
compact(String, CompactionConfig) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
compact(String, Text, Text, boolean, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Starts a full major compaction of the tablets in the range (start, end].
compact(String, Text, Text, boolean, boolean) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
compact(String, Text, Text, List<IteratorSetting>, boolean, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Starts a full major compaction of the tablets in the range (start, end].
compact(String, Text, Text, List<IteratorSetting>, boolean, boolean) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
COMPACT - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
compact_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
compact_args(TabletClientService.compact_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
Performs a deep copy on other.
compact_args(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
compact_call(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compact_call
 
COMPACT_CANCEL - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
COMPACT_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
COMPACT_ID - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
COMPACT_QUAL - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds compact IDs to enable waiting on a compaction to complete
CompactableFile - Interface in org.apache.accumulo.core.client.admin.compaction
A single file ready to compact, that will come in a set of possible candidates.
CompactableFileImpl - Class in org.apache.accumulo.core.metadata
 
CompactableFileImpl(URI, long, long) - Constructor for class org.apache.accumulo.core.metadata.CompactableFileImpl
 
CompactableFileImpl(StoredTabletFile, DataFileValue) - Constructor for class org.apache.accumulo.core.metadata.CompactableFileImpl
 
compacted(KeyExtent, CompactionJob, TabletFile) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
compacting(KeyExtent, CompactionJob, CompactionConfig) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
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.
COMPACTION_AGE_NANOS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
COMPACTION_CANCELED_MSG - Static variable in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
COMPACTION_COORDINATOR_CLIENTPORT - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_DEAD_COMPACTOR_CHECK_INTERVAL - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_FINALIZER_COMPLETION_CHECK_INTERVAL - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_FINALIZER_TSERVER_NOTIFIER_MAXTHREADS - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_MINTHREADS - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_MINTHREADS_TIMEOUT - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_PREFIX - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_SUMMARY_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
COMPACTION_COORDINATOR_THREADCHECK - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_THRIFTCLIENT_PORTSEARCH - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_COORDINATOR_TSERVER_COMPACTION_CHECK_INTERVAL - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTION_SERVICE_COMPACTION_PLANNER_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
compactionAgeNanos - Variable in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
compactionCompleted() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionCompleted
 
compactionCompleted() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionCompleted
 
compactionCompleted(TInfo, TCredentials, String, TKeyExtent, TCompactionStats) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
compactionCompleted(TInfo, TCredentials, String, TKeyExtent, TCompactionStats) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
compactionCompleted(TInfo, TCredentials, String, TKeyExtent, TCompactionStats, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
compactionCompleted(TInfo, TCredentials, String, TKeyExtent, TCompactionStats, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
compactionCompleted_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
compactionCompleted_args(CompactionCoordinatorService.compactionCompleted_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
Performs a deep copy on other.
compactionCompleted_args(TInfo, TCredentials, String, TKeyExtent, TCompactionStats) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
compactionCompleted_call(TInfo, TCredentials, String, TKeyExtent, TCompactionStats, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.compactionCompleted_call
 
compactionCompleted_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
compactionCompleted_result(CompactionCoordinatorService.compactionCompleted_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
Performs a deep copy on other.
CompactionConfig - Class in org.apache.accumulo.core.client.admin
This class exist to pass parameters to TableOperations.compact(String, CompactionConfig)
CompactionConfig() - Constructor for class org.apache.accumulo.core.client.admin.CompactionConfig
 
CompactionConfigurer - Interface in org.apache.accumulo.core.client.admin.compaction
Enables dynamically overriding of per table properties used to create the output file for a compaction.
CompactionConfigurer.InitParameters - Interface in org.apache.accumulo.core.client.admin.compaction
 
CompactionConfigurer.InputParameters - Interface in org.apache.accumulo.core.client.admin.compaction
 
CompactionConfigurer.Overrides - Class in org.apache.accumulo.core.client.admin.compaction
Specifies how the output file should be created for a compaction.
CompactionCoordinatorService - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService
 
CompactionCoordinatorService.AsyncClient - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncClient.cancel_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncClient.compactionCompleted_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncClient.compactionFailed_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncClient.Factory - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncClient.getCompactionJob_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncClient.getCompletedCompactions_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncClient.getRunningCompactions_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncClient.updateCompactionStatus_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncIface - Interface in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncProcessor<I extends CompactionCoordinatorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncProcessor.cancel<I extends CompactionCoordinatorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncProcessor.compactionCompleted<I extends CompactionCoordinatorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncProcessor.compactionFailed<I extends CompactionCoordinatorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncProcessor.getCompactionJob<I extends CompactionCoordinatorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions<I extends CompactionCoordinatorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncProcessor.getRunningCompactions<I extends CompactionCoordinatorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.AsyncProcessor.updateCompactionStatus<I extends CompactionCoordinatorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.cancel_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.cancel_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.cancel_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.cancel_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.Client - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Client.Factory - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.compactionCompleted_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.compactionCompleted_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.compactionCompleted_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.compactionCompleted_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.compactionFailed_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.compactionFailed_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.compactionFailed_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.compactionFailed_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.getCompactionJob_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.getCompactionJob_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.getCompactionJob_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.getCompactionJob_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.getCompletedCompactions_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.getCompletedCompactions_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.getCompletedCompactions_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.getCompletedCompactions_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.getRunningCompactions_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.getRunningCompactions_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.getRunningCompactions_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.getRunningCompactions_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.Iface - Interface in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Processor<I extends CompactionCoordinatorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Processor.cancel<I extends CompactionCoordinatorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Processor.compactionCompleted<I extends CompactionCoordinatorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Processor.compactionFailed<I extends CompactionCoordinatorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Processor.getCompactionJob<I extends CompactionCoordinatorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Processor.getCompletedCompactions<I extends CompactionCoordinatorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Processor.getRunningCompactions<I extends CompactionCoordinatorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.Processor.updateCompactionStatus<I extends CompactionCoordinatorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.updateCompactionStatus_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.updateCompactionStatus_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorService.updateCompactionStatus_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactionCoordinatorService.updateCompactionStatus_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactionCoordinatorServiceThriftClient - Class in org.apache.accumulo.core.rpc.clients
 
CompactionDispatch - Interface in org.apache.accumulo.core.spi.compaction
The dispatch of a CompactionDispatcher
CompactionDispatch.Builder - Interface in org.apache.accumulo.core.spi.compaction
 
CompactionDispatch.ServiceBuilder - Interface in org.apache.accumulo.core.spi.compaction
Required service parameter for CompactionDispatch
CompactionDispatcher - Interface in org.apache.accumulo.core.spi.compaction
Can be configured per table to dispatch compactions to different compaction services.
CompactionDispatcher.DispatchParameters - Interface in org.apache.accumulo.core.spi.compaction
CompactionDispatcher.InitParameters - Interface in org.apache.accumulo.core.spi.compaction
CompactionExecutorId - Class in org.apache.accumulo.core.spi.compaction
A unique identifier for a a compaction executor that a CompactionPlanner can schedule compactions on using a CompactionJob.
CompactionExecutorId(String) - Constructor for class org.apache.accumulo.core.spi.compaction.CompactionExecutorId
 
CompactionExecutorIdImpl - Class in org.apache.accumulo.core.util.compaction
 
CompactionExecutorIdImpl(String) - Constructor for class org.apache.accumulo.core.util.compaction.CompactionExecutorIdImpl
 
compactionFailed() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionFailed
 
compactionFailed() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionFailed
 
compactionFailed(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
compactionFailed(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
compactionFailed(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
compactionFailed(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
compactionFailed_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
compactionFailed_args(CompactionCoordinatorService.compactionFailed_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
Performs a deep copy on other.
compactionFailed_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
compactionFailed_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.compactionFailed_call
 
compactionFailed_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
compactionFailed_result(CompactionCoordinatorService.compactionFailed_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
Performs a deep copy on other.
CompactionJob - Interface in org.apache.accumulo.core.spi.compaction
An immutable object that describes what files to compact and where to compact them.
compactionJobFailed() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compactionJobFailed
 
compactionJobFailed() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compactionJobFailed
 
compactionJobFailed(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
compactionJobFailed(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
compactionJobFailed(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
compactionJobFailed(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
compactionJobFailed_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
compactionJobFailed_args(TabletClientService.compactionJobFailed_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
Performs a deep copy on other.
compactionJobFailed_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
compactionJobFailed_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compactionJobFailed_call
 
compactionJobFinished() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compactionJobFinished
 
compactionJobFinished() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compactionJobFinished
 
compactionJobFinished(TInfo, TCredentials, String, TKeyExtent, long, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
compactionJobFinished(TInfo, TCredentials, String, TKeyExtent, long, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
compactionJobFinished(TInfo, TCredentials, String, TKeyExtent, long, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
compactionJobFinished(TInfo, TCredentials, String, TKeyExtent, long, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
compactionJobFinished_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
compactionJobFinished_args(TabletClientService.compactionJobFinished_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
Performs a deep copy on other.
compactionJobFinished_args(TInfo, TCredentials, String, TKeyExtent, long, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
compactionJobFinished_call(TInfo, TCredentials, String, TKeyExtent, long, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compactionJobFinished_call
 
CompactionJobImpl - Class in org.apache.accumulo.core.util.compaction
An immutable object that describes what files to compact and where to compact them.
CompactionJobImpl(short, CompactionExecutorId, Collection<CompactableFile>, CompactionKind, Optional<Boolean>) - Constructor for class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
CompactionJobPrioritizer - Class in org.apache.accumulo.core.util.compaction
 
CompactionJobPrioritizer() - Constructor for class org.apache.accumulo.core.util.compaction.CompactionJobPrioritizer
 
CompactionKind - Enum in org.apache.accumulo.core.spi.compaction
 
CompactionPlan - Interface in org.apache.accumulo.core.spi.compaction
CompactionPlan.Builder - Interface in org.apache.accumulo.core.spi.compaction
 
CompactionPlanImpl - Class in org.apache.accumulo.core.util.compaction
 
CompactionPlanImpl.BuilderImpl - Class in org.apache.accumulo.core.util.compaction
 
CompactionPlanner - Interface in org.apache.accumulo.core.spi.compaction
Plans compaction work for a compaction service.
CompactionPlanner.InitParameters - Interface in org.apache.accumulo.core.spi.compaction
This interface exists so the API can evolve and additional parameters can be passed to the method in the future.
CompactionPlanner.PlanningParameters - Interface in org.apache.accumulo.core.spi.compaction
This interface exists so the API can evolve and additional parameters can be passed to the method in the future.
CompactionPlannerInitParams - Class in org.apache.accumulo.core.util.compaction
 
CompactionPlannerInitParams(CompactionServiceId, Map<String, String>, ServiceEnvironment) - Constructor for class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
compactions - Variable in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
COMPACTIONS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
 
CompactionSelector - Interface in org.apache.accumulo.core.client.admin.compaction
This class selects which files a user compaction will compact.
CompactionSelector.InitParameters - Interface in org.apache.accumulo.core.client.admin.compaction
 
CompactionSelector.Selection - Class in org.apache.accumulo.core.client.admin.compaction
 
CompactionSelector.SelectionParameters - Interface in org.apache.accumulo.core.client.admin.compaction
 
CompactionServiceId - Class in org.apache.accumulo.core.spi.compaction
A unique identifier for a compaction service
CompactionServices - Interface in org.apache.accumulo.core.spi.compaction
Provider of information about configured compaction services.
CompactionServicesConfig - Class in org.apache.accumulo.core.util.compaction
This class serves to configure compaction services from an AccumuloConfiguration object.
CompactionServicesConfig(AccumuloConfiguration, Consumer<String>) - Constructor for class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
CompactionSettings - Enum in org.apache.accumulo.core.compaction
 
CompactionStrategyConfig - Class in org.apache.accumulo.core.client.admin
Deprecated, for removal: This API element is subject to removal in a future version.
since 2.1.0 CompactionStrategies were deprecated for multiple reasons. First, they do not support the new compaction execution model. Second, they bind selection and output file configuration into a single entity when users need to configure these independently. Third, they use internal Accumulo types and ensuring their stability requires manual effort that may never happen. Fourth, writing a correct compaction strategy was exceedingly difficult as it required knowledge of internal tablet server synchronization in order to avoid causing scans to hang. Fifth although measure were taken to execute compaction strategies in the same manner as before, their execution in the new model has subtle differences that may result in suboptimal compactions. Please migrate to using CompactionConfig.setSelector(PluginConfig) and CompactionConfig.setConfigurer(PluginConfig) as soon as possible.
CompactionStrategyConfig(String) - Constructor for class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
Deprecated.
 
CompactionStrategyConfigUtil - Class in org.apache.accumulo.core.clientImpl
 
CompactionStrategyConfigUtil() - Constructor for class org.apache.accumulo.core.clientImpl.CompactionStrategyConfigUtil
 
compactor - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
compactor - Variable in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
compactor - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
COMPACTOR - Enum constant in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost.Type
 
COMPACTOR - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
COMPACTOR - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
 
COMPACTOR - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args._Fields
 
COMPACTOR - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
COMPACTOR_CLIENT - Enum constant in enum org.apache.accumulo.core.util.ServerServices.Service
 
COMPACTOR_CLIENTPORT - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTOR_COUNT - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TNextCompactionJob._Fields
 
COMPACTOR_MAX_JOB_WAIT_TIME - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTOR_MIN_JOB_WAIT_TIME - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTOR_MINTHREADS - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTOR_MINTHREADS_TIMEOUT - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTOR_PORTSEARCH - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTOR_PREFIX - Enum constant in enum org.apache.accumulo.core.conf.Property
 
COMPACTOR_RUNNING_COMPACTION_IDS_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
COMPACTOR_RUNNING_COMPACTIONS_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
COMPACTOR_THREADCHECK - Enum constant in enum org.apache.accumulo.core.conf.Property
 
compactorCount - Variable in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
CompactorService - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService
 
CompactorService.AsyncClient - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncClient.cancel_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncClient.Factory - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncClient.getActiveCompactions_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncClient.getRunningCompaction_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncClient.getRunningCompactionId_call - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncIface - Interface in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncProcessor<I extends CompactorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncProcessor.cancel<I extends CompactorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncProcessor.getActiveCompactions<I extends CompactorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncProcessor.getRunningCompaction<I extends CompactorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.AsyncProcessor.getRunningCompactionId<I extends CompactorService.AsyncIface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.cancel_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.cancel_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactorService.cancel_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.cancel_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactorService.Client - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.Client.Factory - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.getActiveCompactions_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.getActiveCompactions_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactorService.getActiveCompactions_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.getActiveCompactions_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactorService.getRunningCompaction_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.getRunningCompaction_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactorService.getRunningCompaction_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.getRunningCompaction_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactorService.getRunningCompactionId_args - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.getRunningCompactionId_args._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactorService.getRunningCompactionId_result - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.getRunningCompactionId_result._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CompactorService.Iface - Interface in org.apache.accumulo.core.compaction.thrift
 
CompactorService.Processor<I extends CompactorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.Processor.cancel<I extends CompactorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.Processor.getActiveCompactions<I extends CompactorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.Processor.getRunningCompaction<I extends CompactorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorService.Processor.getRunningCompactionId<I extends CompactorService.Iface> - Class in org.apache.accumulo.core.compaction.thrift
 
CompactorServiceThriftClient - Class in org.apache.accumulo.core.rpc.clients
 
ComparableBytes - Class in org.apache.accumulo.core.dataImpl
An array of bytes wrapped so as to extend Hadoop's BinaryComparable class.
ComparableBytes(byte[]) - Constructor for class org.apache.accumulo.core.dataImpl.ComparableBytes
Creates a new byte wrapper.
ComparablePair<A extends Comparable<A>,B extends Comparable<B>> - Class in org.apache.accumulo.core.util
 
ComparablePair(A, B) - Constructor for class org.apache.accumulo.core.util.ComparablePair
 
Comparator() - Constructor for class org.apache.accumulo.core.data.Value.Comparator
constructor
compare(byte[], byte[]) - Method in class org.apache.accumulo.core.util.ByteArrayComparator
 
compare(byte[], int, int, byte[], int, int) - Method in class org.apache.accumulo.core.data.Value.Comparator
 
compare(ColumnVisibility.Node, ColumnVisibility.Node) - Method in class org.apache.accumulo.core.security.ColumnVisibility.NodeComparator
 
compareBytes(ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.data.ByteSequence
Compares the two given byte sequences, byte by byte, returning a negative, zero, or positive result if the first sequence is less than, equal to, or greater than the second.
compareColumnFamily(Text) - Method in class org.apache.accumulo.core.data.Key
Compares this key's column family with another.
compareColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
Compares this key's column qualifier with another.
compareRow(Text) - Method in class org.apache.accumulo.core.data.Key
Compares this key's row ID with another.
compareTo(byte[]) - Method in class org.apache.accumulo.core.data.Value
Compares the bytes in this object to the specified byte array
compareTo(Object) - Method in class org.apache.accumulo.core.data.Value
Define the sort order of the BytesWritable.
compareTo(AuthenticationToken.TokenProperty) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
compareTo(TabletLocator.TabletLocation) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocation
 
compareTo(ClientService.authenticate_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
compareTo(ClientService.authenticate_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
compareTo(ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
compareTo(ClientService.authenticateUser_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
compareTo(ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
compareTo(ClientService.bulkImportFiles_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
compareTo(ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
compareTo(ClientService.changeAuthorizations_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
compareTo(ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
compareTo(ClientService.changeLocalUserPassword_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
compareTo(ClientService.checkClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
compareTo(ClientService.checkClass_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
compareTo(ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
compareTo(ClientService.checkNamespaceClass_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
compareTo(ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
compareTo(ClientService.checkTableClass_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
compareTo(ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
compareTo(ClientService.createLocalUser_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
compareTo(ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
compareTo(ClientService.dropLocalUser_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
compareTo(ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
compareTo(ClientService.getConfiguration_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
compareTo(ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
compareTo(ClientService.getDiskUsage_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
compareTo(ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
compareTo(ClientService.getInstanceId_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
compareTo(ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
compareTo(ClientService.getNamespaceConfiguration_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
compareTo(ClientService.getNamespaceProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
compareTo(ClientService.getNamespaceProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
compareTo(ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
compareTo(ClientService.getRootTabletLocation_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
compareTo(ClientService.getSystemProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
compareTo(ClientService.getSystemProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
compareTo(ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
compareTo(ClientService.getTableConfiguration_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
compareTo(ClientService.getTableProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
compareTo(ClientService.getTableProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
compareTo(ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
compareTo(ClientService.getUserAuthorizations_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
compareTo(ClientService.getVersionedNamespaceProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
compareTo(ClientService.getVersionedNamespaceProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
compareTo(ClientService.getVersionedSystemProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
compareTo(ClientService.getVersionedSystemProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
compareTo(ClientService.getVersionedTableProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
compareTo(ClientService.getVersionedTableProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
compareTo(ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
compareTo(ClientService.getZooKeepers_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
compareTo(ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
compareTo(ClientService.grantNamespacePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
compareTo(ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
compareTo(ClientService.grantSystemPermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
compareTo(ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
compareTo(ClientService.grantTablePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
compareTo(ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
compareTo(ClientService.hasNamespacePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
compareTo(ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
compareTo(ClientService.hasSystemPermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
compareTo(ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
compareTo(ClientService.hasTablePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
compareTo(ClientService.isActive_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
compareTo(ClientService.isActive_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
compareTo(ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
compareTo(ClientService.listLocalUsers_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
compareTo(ClientService.ping_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
compareTo(ClientService.ping_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
compareTo(ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
compareTo(ClientService.revokeNamespacePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
compareTo(ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
compareTo(ClientService.revokeSystemPermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
compareTo(ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
compareTo(ClientService.revokeTablePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
compareTo(TDiskUsage) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
compareTo(ThriftConcurrentModificationException) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
compareTo(ThriftNotActiveServiceException) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
compareTo(ThriftSecurityException) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
compareTo(ThriftTableOperationException) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
compareTo(ThriftTest.fails_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
compareTo(ThriftTest.fails_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
compareTo(ThriftTest.success_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
compareTo(ThriftTest.success_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
compareTo(ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
compareTo(ThriftTest.throwsError_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
compareTo(TVersionedProperties) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
compareTo(CompactionCoordinatorService.cancel_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
compareTo(CompactionCoordinatorService.cancel_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
compareTo(CompactionCoordinatorService.compactionCompleted_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
compareTo(CompactionCoordinatorService.compactionCompleted_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
compareTo(CompactionCoordinatorService.compactionFailed_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
compareTo(CompactionCoordinatorService.compactionFailed_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
compareTo(CompactionCoordinatorService.getCompactionJob_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
compareTo(CompactionCoordinatorService.getCompactionJob_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
compareTo(CompactionCoordinatorService.getCompletedCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
compareTo(CompactionCoordinatorService.getCompletedCompactions_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
compareTo(CompactionCoordinatorService.getRunningCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
compareTo(CompactionCoordinatorService.getRunningCompactions_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
compareTo(CompactionCoordinatorService.updateCompactionStatus_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
compareTo(CompactionCoordinatorService.updateCompactionStatus_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
compareTo(CompactorService.cancel_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
compareTo(CompactorService.cancel_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
compareTo(CompactorService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
compareTo(CompactorService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
compareTo(CompactorService.getRunningCompaction_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
compareTo(CompactorService.getRunningCompaction_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
compareTo(CompactorService.getRunningCompactionId_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
compareTo(CompactorService.getRunningCompactionId_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
compareTo(TCompactionStatusUpdate) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
compareTo(TExternalCompaction) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
compareTo(TExternalCompactionList) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
compareTo(TNextCompactionJob) - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
compareTo(UnknownCompactionIdException) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
compareTo(ByteSequence) - Method in class org.apache.accumulo.core.data.ByteSequence
 
compareTo(Column) - Method in class org.apache.accumulo.core.data.Column
Compares this column to another.
compareTo(Key) - Method in class org.apache.accumulo.core.data.Key
 
compareTo(Key, PartialKey) - Method in class org.apache.accumulo.core.data.Key
Compares elements of a key given by a PartialKey.
compareTo(Range) - Method in class org.apache.accumulo.core.data.Range
Compares this range to another range.
compareTo(TabletId) - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
compareTo(KeyExtent) - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
compareTo(InitialMultiScan) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
compareTo(InitialScan) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
compareTo(IterInfo) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
compareTo(MapFileInfo) - Method in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
compareTo(MultiScanResult) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
compareTo(ScanResult) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
compareTo(TCMResult) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
compareTo(TColumn) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
compareTo(TCondition) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
compareTo(TConditionalMutation) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
compareTo(TConditionalSession) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
compareTo(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
compareTo(TKey) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
compareTo(TKeyExtent) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
compareTo(TKeyValue) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
compareTo(TMutation) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
compareTo(TRange) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
compareTo(TRowRange) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
compareTo(TSummaries) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
compareTo(TSummarizerConfiguration) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
compareTo(TSummary) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
compareTo(TSummaryRequest) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
compareTo(UpdateErrors) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
compareTo(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
compareTo(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
 
compareTo(BlockIndex.BlockIndexEntry) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
compareTo(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
compareTo(GcCandidate) - Method in class org.apache.accumulo.core.gc.GcCandidate
 
compareTo(ReferenceFile) - Method in class org.apache.accumulo.core.gc.ReferenceFile
 
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(DeadServer) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
compareTo(FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
compareTo(FateService.beginFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
compareTo(FateService.cancelFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
compareTo(FateService.cancelFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
compareTo(FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
compareTo(FateService.executeFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
compareTo(FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
compareTo(FateService.finishFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
compareTo(FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
compareTo(FateService.waitForFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
compareTo(ManagerClientService.drainReplicationTable_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
compareTo(ManagerClientService.drainReplicationTable_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
compareTo(ManagerClientService.getActiveTservers_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
compareTo(ManagerClientService.getActiveTservers_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
compareTo(ManagerClientService.getDelegationToken_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
compareTo(ManagerClientService.getDelegationToken_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
compareTo(ManagerClientService.getManagerStats_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
compareTo(ManagerClientService.getManagerStats_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
compareTo(ManagerClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
compareTo(ManagerClientService.initiateFlush_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
compareTo(ManagerClientService.modifyNamespaceProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
compareTo(ManagerClientService.modifyNamespaceProperties_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
compareTo(ManagerClientService.modifySystemProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
compareTo(ManagerClientService.modifySystemProperties_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
compareTo(ManagerClientService.modifyTableProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
compareTo(ManagerClientService.modifyTableProperties_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
compareTo(ManagerClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
compareTo(ManagerClientService.removeNamespaceProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
compareTo(ManagerClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
compareTo(ManagerClientService.removeSystemProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
compareTo(ManagerClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
compareTo(ManagerClientService.removeTableProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
compareTo(ManagerClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
compareTo(ManagerClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
compareTo(ManagerClientService.setManagerGoalState_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
compareTo(ManagerClientService.setManagerGoalState_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
compareTo(ManagerClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
compareTo(ManagerClientService.setNamespaceProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
compareTo(ManagerClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
compareTo(ManagerClientService.setSystemProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
compareTo(ManagerClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
compareTo(ManagerClientService.setTableProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
compareTo(ManagerClientService.shutdown_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
compareTo(ManagerClientService.shutdown_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
compareTo(ManagerClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
compareTo(ManagerClientService.shutdownTabletServer_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
compareTo(ManagerClientService.waitForBalance_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
compareTo(ManagerClientService.waitForBalance_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
compareTo(ManagerClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
compareTo(ManagerClientService.waitForFlush_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
compareTo(ManagerMonitorInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
compareTo(RecoveryException) - Method in exception org.apache.accumulo.core.manager.thrift.RecoveryException
 
compareTo(TabletSplit) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
compareTo(ThriftPropertyException) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
compareTo(BulkImportStatus) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
compareTo(Compacting) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
compareTo(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
compareTo(TableInfo) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
compareTo(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
compareTo(MetadataTime) - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
compareTo(TabletFile) - Method in class org.apache.accumulo.core.metadata.TabletFile
 
compareTo(TServerInstance) - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
compareTo(KeyValues) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
compareTo(RemoteReplicationException) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
compareTo(ReplicationCoordinator.getServicerAddress_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
compareTo(ReplicationCoordinator.getServicerAddress_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
compareTo(ReplicationCoordinatorException) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
compareTo(ReplicationServicer.replicateKeyValues_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
compareTo(ReplicationServicer.replicateKeyValues_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
compareTo(ReplicationServicer.replicateLog_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
compareTo(ReplicationServicer.replicateLog_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
compareTo(WalEdits) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
compareTo(TAuthenticationKey) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
compareTo(TAuthenticationTokenIdentifier) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
compareTo(TCredentials) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
compareTo(TDelegationToken) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
compareTo(TDelegationTokenConfig) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
compareTo(TableStatistics) - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
compareTo(TabletServerId) - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
compareTo(TabletStatistics) - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
compareTo(TServerStatus) - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
compareTo(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
compareTo(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
compareTo(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
compareTo(ConstraintViolationException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
compareTo(InputFile) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
compareTo(IteratorConfig) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
compareTo(NoSuchScanIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
compareTo(NotServingTabletException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
compareTo(ScanServerBusyException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException
 
compareTo(TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
compareTo(TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
compareTo(TabletClientService.bulkImport_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
compareTo(TabletClientService.cancelUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
compareTo(TabletClientService.cancelUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
compareTo(TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
compareTo(TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
compareTo(TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
compareTo(TabletClientService.closeUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
compareTo(TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
compareTo(TabletClientService.compactionJobFailed_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
compareTo(TabletClientService.compactionJobFinished_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
compareTo(TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
compareTo(TabletClientService.conditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
compareTo(TabletClientService.contiuneGetSummaries_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
compareTo(TabletClientService.contiuneGetSummaries_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
compareTo(TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
compareTo(TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
compareTo(TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
compareTo(TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
compareTo(TabletClientService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
compareTo(TabletClientService.getActiveLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
compareTo(TabletClientService.getActiveLogs_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
compareTo(TabletClientService.getCompactionQueueInfo_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
compareTo(TabletClientService.getCompactionQueueInfo_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
compareTo(TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
compareTo(TabletClientService.getHistoricalStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
compareTo(TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
compareTo(TabletClientService.getTabletServerStatus_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
compareTo(TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
compareTo(TabletClientService.getTabletStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
compareTo(TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
compareTo(TabletClientService.halt_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
compareTo(TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
compareTo(TabletClientService.invalidateConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
compareTo(TabletClientService.loadFiles_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
compareTo(TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
compareTo(TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
compareTo(TabletClientService.reserveCompactionJob_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
compareTo(TabletClientService.reserveCompactionJob_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
compareTo(TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
compareTo(TabletClientService.splitTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
compareTo(TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
compareTo(TabletClientService.startConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
compareTo(TabletClientService.startGetSummaries_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
compareTo(TabletClientService.startGetSummaries_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
compareTo(TabletClientService.startGetSummariesForPartition_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
compareTo(TabletClientService.startGetSummariesForPartition_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
compareTo(TabletClientService.startGetSummariesFromFiles_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
compareTo(TabletClientService.startGetSummariesFromFiles_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_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(TabletScanClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
compareTo(TabletScanClientService.closeMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
compareTo(TabletScanClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
compareTo(TabletScanClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
compareTo(TabletScanClientService.continueMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
compareTo(TabletScanClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
compareTo(TabletScanClientService.continueScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
compareTo(TabletScanClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
compareTo(TabletScanClientService.getActiveScans_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
compareTo(TabletScanClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
compareTo(TabletScanClientService.startMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
compareTo(TabletScanClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
compareTo(TabletScanClientService.startScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
compareTo(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
compareTo(TCompactionQueueSummary) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
compareTo(TCompactionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
compareTo(TExternalCompactionJob) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
compareTo(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
compareTo(TooManyFilesException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
compareTo(TSampleNotPresentException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
compareTo(TSamplerConfiguration) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
compareTo(TInfo) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
compareTo(ColumnFQ) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
compareTo(ComparablePair<A, B>) - Method in class org.apache.accumulo.core.util.ComparablePair
 
compareTo(HostAndPort) - Method in class org.apache.accumulo.core.util.HostAndPort
HostAndPort must implement compareTo.
compareTo(ServerServices) - Method in class org.apache.accumulo.core.util.ServerServices
 
compareTo(T) - Method in class org.apache.accumulo.core.data.AbstractId
 
compatibleWith(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Test compatibility.
CompletableFutureUtil - Class in org.apache.accumulo.core.util
 
CompletableFutureUtil() - Constructor for class org.apache.accumulo.core.util.CompletableFutureUtil
 
compress(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
compress(List<? extends KeyValue>) - Static method in class org.apache.accumulo.core.data.Key
Compresses a list of key/value pairs before sending them via thrift.
compress(IteratorSetting[]) - Method in class org.apache.accumulo.core.clientImpl.CompressedIterators
 
CompressedIterators - Class in org.apache.accumulo.core.clientImpl
 
CompressedIterators() - Constructor for class org.apache.accumulo.core.clientImpl.CompressedIterators
 
CompressedIterators(List<String>) - Constructor for class org.apache.accumulo.core.clientImpl.CompressedIterators
 
CompressedIterators.IterConfig - Class in org.apache.accumulo.core.clientImpl
 
compression - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
Compression - Class in org.apache.accumulo.core.file.rfile.bcfile
Compression related stuff.
CompressionAlgorithm - Class in org.apache.accumulo.core.file.rfile.bcfile
There is a static initializer in Compression that finds all implementations of CompressionAlgorithmConfiguration and initializes a CompressionAlgorithm instance.
CompressionAlgorithm(CompressionAlgorithmConfiguration, Configuration) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
CompressionAlgorithm.FinishOnFlushCompressionStream - Class in org.apache.accumulo.core.file.rfile.bcfile
 
CompressionAlgorithmConfiguration - Interface in org.apache.accumulo.core.spi.file.rfile.compression
 
CompressionConfigurer - Class in org.apache.accumulo.core.client.admin.compaction
A compaction configurer that can adjust the compression configuration for a compaction when the sum of the input file sizes exceeds a threshold.
CompressionConfigurer() - Constructor for class org.apache.accumulo.core.client.admin.compaction.CompressionConfigurer
 
computeFileToTabletMappings(FileSystem, TableId, Map<String, String>, Path, Executor, ClientContext, int) - Method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
computeReseekRange(Range) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Possibly expand range to include everything for the key prefix we are working with.
concat(byte[]...) - Static method in class org.apache.accumulo.core.clientImpl.lexicoder.ByteUtils
Concatenates byte arrays with 0x00 as a delimiter
CONCURRENT_HASHMAP - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Overhead for ConcurrentHashMap
CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Overhead for ConcurrentHashMap.Entry
CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Overhead for ConcurrentHashMap.Segment
condition - Variable in class org.apache.accumulo.core.logging.ConditionalLogger
 
Condition - Class in org.apache.accumulo.core.data
Conditions that must be met on a particular column in a row.
Condition(byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Condition
Creates a new condition.
Condition(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Condition
Creates a new condition.
Condition(ByteSequence, ByteSequence) - Constructor for class org.apache.accumulo.core.data.Condition
Creates a new condition.
Condition(Text, Text) - Constructor for class org.apache.accumulo.core.data.Condition
Creates a new condition.
CONDITIONAL_WRITER_CLEANUP_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
CONDITIONAL_WRITER_DURABILITY - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
CONDITIONAL_WRITER_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
CONDITIONAL_WRITER_THREADS_MAX - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
CONDITIONAL_WRITER_TIMEOUT_MAX - Enum constant in enum org.apache.accumulo.core.conf.ClientProperty
 
ConditionalLogger - Class in org.apache.accumulo.core.logging
Logger that wraps another Logger and only emits a log message once per the supplied duration.
ConditionalLogger(Logger, BiFunction<String, List<Object>, Boolean>) - Constructor for class org.apache.accumulo.core.logging.ConditionalLogger
 
ConditionalLogger.DeduplicatingLogger - Class in org.apache.accumulo.core.logging
A Logger implementation that will suppress duplicate messages within the supplied duration.
ConditionalLogger.EscalatingLogger - Class in org.apache.accumulo.core.logging
A Logger implementation that will log a message at the supplied elevated level if it has not been seen in the supplied duration.
ConditionalMutation - Class in org.apache.accumulo.core.data
A Mutation that contains a list of conditions that must all be met before the mutation is applied.
ConditionalMutation(byte[], int, int, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(byte[], Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(CharSequence, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(ByteSequence, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(ConditionalMutation) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
ConditionalMutation(Text, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
 
conditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
 
conditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
 
conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback<List<TCMResult>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback<List<TCMResult>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
conditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
conditionalUpdate_args(TabletClientService.conditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
Performs a deep copy on other.
conditionalUpdate_args(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
conditionalUpdate_call(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback<List<TCMResult>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.conditionalUpdate_call
 
conditionalUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
conditionalUpdate_result(List<TCMResult>, NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
conditionalUpdate_result(TabletClientService.conditionalUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
Performs a deep copy on other.
ConditionalWriter - Interface in org.apache.accumulo.core.client
ConditionalWriter provides the ability to do efficient, atomic read-modify-write operations on rows.
ConditionalWriter.Result - Class in org.apache.accumulo.core.client
 
ConditionalWriter.Status - Enum in org.apache.accumulo.core.client
 
ConditionalWriterConfig - Class in org.apache.accumulo.core.client
 
ConditionalWriterConfig() - Constructor for class org.apache.accumulo.core.client.ConditionalWriterConfig
 
ConditionalWriterImpl - Class in org.apache.accumulo.core.clientImpl
 
conditions - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
CONDITIONS - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
 
conf - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
 
conf(Configuration) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
config - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
config - Variable in class org.apache.accumulo.core.util.format.DefaultFormatter
 
CONFIG - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
CONFIG_ID - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
 
ConfigCheckException(String) - Constructor for exception org.apache.accumulo.core.conf.ConfigCheckUtil.ConfigCheckException
Creates a new exception with the given message.
ConfigCheckUtil - Class in org.apache.accumulo.core.conf
A utility class for validating AccumuloConfiguration instances.
ConfigCheckUtil() - Constructor for class org.apache.accumulo.core.conf.ConfigCheckUtil
 
ConfigCheckUtil.ConfigCheckException - Exception in org.apache.accumulo.core.conf
The exception thrown when ConfigCheckUtil.validate(Iterable, String) fails.
configId - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
ConfigOpts - Class in org.apache.accumulo.core.cli
 
ConfigOpts() - Constructor for class org.apache.accumulo.core.cli.ConfigOpts
 
ConfigOpts.NullSplitter - Class in org.apache.accumulo.core.cli
 
ConfigurableScanServerHostSelector - Class in org.apache.accumulo.core.spi.scan
Extension of the ConfigurableScanServerSelector that can be used when there are multiple ScanServers running on the same host and for some reason, like using a shared off-heap cache, sending scans for the same tablet to the same host may provide a better experience.
ConfigurableScanServerHostSelector() - Constructor for class org.apache.accumulo.core.spi.scan.ConfigurableScanServerHostSelector
 
ConfigurableScanServerSelector - Class in org.apache.accumulo.core.spi.scan
The default Accumulo selector for scan servers.
ConfigurableScanServerSelector() - Constructor for class org.apache.accumulo.core.spi.scan.ConfigurableScanServerSelector
 
ConfigurableScanServerSelector.Profile - Class in org.apache.accumulo.core.spi.scan
 
ConfigurationCopy - Class in org.apache.accumulo.core.conf
An AccumuloConfiguration which holds a flat copy of properties defined in another configuration
ConfigurationCopy() - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
Creates a new empty configuration.
ConfigurationCopy(Iterable<Map.Entry<String, String>>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
Creates a new configuration.
ConfigurationCopy(Map<String, String>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
Creates a new configuration.
ConfigurationCopy(Stream<Map.Entry<String, String>>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
Creates a new configuration.
ConfigurationDocGen - Class in org.apache.accumulo.core.conf
This class generates documentation to inform users of the available configuration properties in a presentable form.
ConfigurationImpl - Class in org.apache.accumulo.core.util
The implementation class used for providing SPI configuration without exposing internal types.
ConfigurationImpl(AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.util.ConfigurationImpl
 
ConfigurationType - Enum in org.apache.accumulo.core.clientImpl.thrift
 
ConfigurationTypeHelper - Class in org.apache.accumulo.core.conf
 
ConfigurationTypeHelper() - Constructor for class org.apache.accumulo.core.conf.ConfigurationTypeHelper
 
ConfiguratorBase - Class in org.apache.accumulo.core.clientImpl.mapreduce.lib
 
ConfiguratorBase() - Constructor for class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
 
ConfiguratorBase.ConnectorInfo - Enum in org.apache.accumulo.core.clientImpl.mapreduce.lib
Specifies that connection info was configured
ConfiguratorBase.GeneralOpts - Enum in org.apache.accumulo.core.clientImpl.mapreduce.lib
Configuration keys for general configuration options.
ConfiguratorBase.InstanceOpts - Enum in org.apache.accumulo.core.clientImpl.mapreduce.lib
Configuration keys for available Instance types.
ConfiguratorBase.TokenSource - Enum in org.apache.accumulo.core.clientImpl.mapreduce.lib
 
CONNECTION_ERROR - Enum constant in enum org.apache.accumulo.core.client.security.SecurityErrorCode
 
CONNECTION_ERROR - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
Connector - Class in org.apache.accumulo.core.client
Deprecated.
since 2.0.0. Use AccumuloClient for writing new code. Connector is available for existing code. Use Connector.from(AccumuloClient) as a bridge between the two.
Connector() - Constructor for class org.apache.accumulo.core.client.Connector
Deprecated.
 
CONNECTOR - Enum constant in enum org.apache.accumulo.core.singletons.SingletonManager.Mode
In this mode singletons are never disabled unless the mode is set back to CLIENT.
ConnectorImpl - Class in org.apache.accumulo.core.clientImpl
Deprecated.
ConnectorImpl(ClientContext) - Constructor for class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
Constants - Class in org.apache.accumulo.core
 
Constants() - Constructor for class org.apache.accumulo.core.Constants
 
CONSTRAIN_CLASS - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
 
constrainClass - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
constrainClass - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
Constraint - Interface in org.apache.accumulo.core.constraints
Deprecated.
since 2.1.0 Use Constraint
Constraint - Interface in org.apache.accumulo.core.data.constraints
Constraint objects are used to determine if mutations will be applied to a table.
Constraint.Environment - Interface in org.apache.accumulo.core.constraints
Deprecated.
The environment within which a constraint exists.
Constraint.Environment - Interface in org.apache.accumulo.core.data.constraints
The environment within which a constraint exists.
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
A summary of constraint violations across some number of mutations.
ConstraintViolationSummary(String, short, String, long) - Constructor for class org.apache.accumulo.core.data.ConstraintViolationSummary
Creates a new summary.
ConstraintViolationSummary(TConstraintViolationSummary) - Constructor for class org.apache.accumulo.core.data.ConstraintViolationSummary
Creates a new summary from Thrift.
consume() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.ServerSkippingIterator
 
consume() - Method in class org.apache.accumulo.core.iterators.SkippingIterator
 
consume() - Method in class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
consumeBuffer(int) - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
contains(byte[]) - Method in class org.apache.accumulo.core.security.Authorizations
Checks whether this object contains the given authorization.
contains(String) - Method in class org.apache.accumulo.core.security.Authorizations
Checks whether this object contains the given authorization.
contains(ByteSequence) - Method in interface org.apache.accumulo.core.security.AuthorizationContainer
Checks whether this object contains the given authorization.
contains(ByteSequence) - Method in class org.apache.accumulo.core.security.Authorizations
Checks whether this object contains the given authorization.
contains(Key) - Method in class org.apache.accumulo.core.data.Range
Determines if the given key falls within this range.
contains(Key) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnSet
 
contains(KeyExtent) - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Determine if another KeyExtent is wholly contained within the range of this one.
contains(BinaryComparable) - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Determine if the provided row is contained within the range of this KeyExtent.
containsKey(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
containsKey(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
 
containsPath(Path) - Method in interface org.apache.accumulo.core.volume.Volume
Determine if the Path is contained in Volume.
containsPath(Path) - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
containsValue(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
contentEquals(byte[]) - Method in class org.apache.accumulo.core.data.Value
Compares the bytes in this object to the specified byte array
ContextClassLoaderEnvironment - Interface in org.apache.accumulo.core.spi.common
The environment provided to the context class loader factory for its use
ContextClassLoaderFactory - Interface in org.apache.accumulo.core.spi.common
The ContextClassLoaderFactory provides a mechanism for various Accumulo components to use a custom ClassLoader for specific contexts, such as loading table iterators.
contextIterators(TaskAttemptContext, String) - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
Extracts Iterators settings from the context to be used by RecordReader.
contextIterators(TaskAttemptContext, String) - Method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RecordReaderBase
Deprecated.
continueMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.continueMultiScan
 
continueMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.continueMultiScan
 
continueMultiScan(TInfo, long, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client
 
continueMultiScan(TInfo, long, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Iface
 
continueMultiScan(TInfo, long, long, AsyncMethodCallback<MultiScanResult>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient
 
continueMultiScan(TInfo, long, long, AsyncMethodCallback<MultiScanResult>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncIface
 
continueMultiScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
continueMultiScan_args(TabletScanClientService.continueMultiScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
Performs a deep copy on other.
continueMultiScan_args(TInfo, long, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
continueMultiScan_call(TInfo, long, long, AsyncMethodCallback<MultiScanResult>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.continueMultiScan_call
 
continueMultiScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
continueMultiScan_result(MultiScanResult, NoSuchScanIDException, TSampleNotPresentException, ScanServerBusyException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
continueMultiScan_result(TabletScanClientService.continueMultiScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
Performs a deep copy on other.
continueScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.continueScan
 
continueScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.continueScan
 
continueScan(TInfo, long, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client
 
continueScan(TInfo, long, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Iface
 
continueScan(TInfo, long, long, AsyncMethodCallback<ScanResult>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient
 
continueScan(TInfo, long, long, AsyncMethodCallback<ScanResult>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncIface
 
continueScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
continueScan_args(TabletScanClientService.continueScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
Performs a deep copy on other.
continueScan_args(TInfo, long, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
continueScan_call(TInfo, long, long, AsyncMethodCallback<ScanResult>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.continueScan_call
 
continueScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
continueScan_result(ScanResult, NoSuchScanIDException, NotServingTabletException, TooManyFilesException, TSampleNotPresentException, ScanServerBusyException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
continueScan_result(TabletScanClientService.continueScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
Performs a deep copy on other.
contiuneGetSummaries() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.contiuneGetSummaries
 
contiuneGetSummaries() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.contiuneGetSummaries
 
contiuneGetSummaries(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
contiuneGetSummaries(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
contiuneGetSummaries(TInfo, long, AsyncMethodCallback<TSummaries>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
contiuneGetSummaries(TInfo, long, AsyncMethodCallback<TSummaries>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
contiuneGetSummaries_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
contiuneGetSummaries_args(TabletClientService.contiuneGetSummaries_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
Performs a deep copy on other.
contiuneGetSummaries_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
contiuneGetSummaries_call(TInfo, long, AsyncMethodCallback<TSummaries>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.contiuneGetSummaries_call
 
contiuneGetSummaries_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
contiuneGetSummaries_result(TSummaries, NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
contiuneGetSummaries_result(TabletClientService.contiuneGetSummaries_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
Performs a deep copy on other.
convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.AuthConverter
 
convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.PasswordConverter
 
convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.VisibilityConverter
 
convert(String) - Method in class org.apache.accumulo.core.compaction.NullType
 
convert(String) - Method in class org.apache.accumulo.core.util.Merge.MemoryConverter
 
convert(Key, Value, Consumer<K>) - Method in interface org.apache.accumulo.core.client.summary.CountingSummarizer.Converter
 
converter() - Method in class org.apache.accumulo.core.client.summary.CountingSummarizer
 
converter() - Method in class org.apache.accumulo.core.client.summary.summarizers.AuthorizationSummarizer
 
converter() - Method in class org.apache.accumulo.core.client.summary.summarizers.FamilySummarizer
 
converter() - Method in class org.apache.accumulo.core.client.summary.summarizers.VisibilitySummarizer
 
convertItersAndLoad(IteratorUtil.IteratorScope, SortedKeyValueIterator<Key, Value>, AccumuloConfiguration, List<IteratorSetting>, IteratorEnvironment) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
Convert the list of iterators to IterInfo objects and then load the stack.
convertRow(Iterator<E>, EnumSet<TabletMetadata.ColumnType>, boolean) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
COORDINATOR - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
COORDINATOR_FINALIZER_BACKGROUND_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
COORDINATOR_FINALIZER_NOTIFIER_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
copier() - Method in class org.apache.accumulo.core.client.summary.CountingSummarizer
Override this if your key type is mutable and subject to change.
copier() - Method in class org.apache.accumulo.core.client.summary.summarizers.FamilySummarizer
 
copier() - Method in class org.apache.accumulo.core.client.summary.summarizers.VisibilitySummarizer
 
copy() - Method in class org.apache.accumulo.core.util.Stat
 
copy(byte[]) - Method in class org.apache.accumulo.core.data.Value
Sets the byte data of this value.
COPY_FILES - Enum constant in enum org.apache.accumulo.core.master.thrift.BulkImportState
 
copyOf(KeyExtent) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
Create a copy of a provided KeyExtent.
copyPartialKey(Key, PartialKey) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Creates a copy of key, copying only the parts of the key specified in part.
copyStats(ZooCache.ZcStat, ZooCache.ZcStat) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Helper method to copy stats from the cached stat into userStat
CORE_PACKAGE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
COULD_NOT_APPLY - Enum constant in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
 
COULD_NOT_DESERIALIZE - Enum constant in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
 
count - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
COUNT - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
COUNT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
countCompactors(String, ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
COUNTER_STAT_PREFIX - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
This prefixes all counters when emitting statistics in Summarizer.Collector.summarize(Summarizer.StatisticConsumer).
CounterSummary - Class in org.apache.accumulo.core.client.summary
This a convenience class for interpreting summary data generated by implementations of CountingSummarizer
CounterSummary(Summary) - Constructor for class org.apache.accumulo.core.client.summary.CounterSummary
This method will call CounterSummary(Summary, boolean) with true.
CounterSummary(Summary, boolean) - Constructor for class org.apache.accumulo.core.client.summary.CounterSummary
 
CountingIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
 
CountingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.CountingIterator
 
CountingSummarizer<K> - Class in org.apache.accumulo.core.client.summary
This class counts arbitrary keys while defending against too many keys and keys that are too long.
CountingSummarizer() - Constructor for class org.apache.accumulo.core.client.summary.CountingSummarizer
 
CountingSummarizer.Converter<K> - Interface in org.apache.accumulo.core.client.summary
A function that converts key values to zero or more counter objects.
cq - Variable in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
CQ - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
create() - Static method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
Initializes an empty configuration object to be further configured with other methods on the class.
create() - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
create() - Method in interface org.apache.accumulo.core.fate.TStore
Create a new transaction id
create() - Method in class org.apache.accumulo.core.fate.ZooStore
 
create() - Method in interface org.apache.accumulo.core.metrics.MeterRegistryFactory
Deprecated.
 
create(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Create an empty namespace with no initial configuration.
create(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Create a table with no special configuration.
create(String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
create(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
create(String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Deprecated.
create(String, boolean, TimeType) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Deprecated.
create(String, NewTableConfiguration) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Create a table with specified configuration.
create(String, NewTableConfiguration) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
create(String, SharedRateLimiterFactory.RateProvider) - Method in class org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory
Lookup the RateLimiter associated with the specified name, or create a new one for that name.
create(URI, long, long) - Static method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
create(MeterRegistryFactory.InitParameters) - Method in class org.apache.accumulo.core.spi.metrics.LoggingMeterRegistryFactory
 
create(MeterRegistryFactory.InitParameters) - Method in interface org.apache.accumulo.core.spi.metrics.MeterRegistryFactory
Called on metrics initialization.
create(HostAndPort, long) - Static method in class org.apache.accumulo.core.rpc.TTimeoutTransport
Creates a Thrift TTransport to the given address with the given timeout.
create(Path) - Method in interface org.apache.accumulo.core.clientImpl.bulk.BulkSerialize.Output
 
CREATE - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
CREATE - Enum constant in enum org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeMissingPolicy
 
CREATE_NAMESPACE - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
CREATE_TABLE - Enum constant in enum org.apache.accumulo.core.security.NamespacePermission
 
CREATE_TABLE - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
CREATE_USER - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
createBatchDeleter(String, Authorizations, int) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create BatchDeleter.
createBatchDeleter(String, Authorizations, int) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create BatchDeleter
createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
Factory method to create BatchDeleter
createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createBatchScanner(String) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a BatchScanner with all of user's authorizations and the number of query threads configured when AccumuloClient was created.
createBatchScanner(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createBatchScanner(String, Authorizations) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a BatchScanner connected to Accumulo.
createBatchScanner(String, Authorizations) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createBatchScanner(String, Authorizations, int) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a BatchScanner connected to Accumulo.
createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
Factory method to create a BatchScanner connected to Accumulo.
createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createBatchWriter(String) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a BatchWriter.
createBatchWriter(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createBatchWriter(String, BatchWriterConfig) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a BatchWriter connected to Accumulo.
createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
Factory method to create a BatchWriter connected to Accumulo.
createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createCache(BlockCacheManager.Configuration, CacheType) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheManager
 
createCache(BlockCacheManager.Configuration, CacheType) - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCacheManager
 
createCache(BlockCacheManager.Configuration, CacheType) - Method in class org.apache.accumulo.core.spi.cache.BlockCacheManager
Create a block cache using the supplied configuration
createClient(ThriftClientTypes<T>, TTransport) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a Thrift client using the given factory and transport
createClientTransport(HostAndPort, int, SslConnectionParams, SaslConnectionParams) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a TTransport for clients to the given address with the provided socket timeout and session-layer configuration
createComparator(ScanPrioritizer.CreateParameters) - Method in class org.apache.accumulo.core.spi.scan.HintScanPrioritizer
 
createComparator(ScanPrioritizer.CreateParameters) - Method in class org.apache.accumulo.core.spi.scan.IdleRatioScanPrioritizer
 
createComparator(ScanPrioritizer.CreateParameters) - Method in interface org.apache.accumulo.core.spi.scan.ScanPrioritizer
 
createCompressionStream(OutputStream, Compressor, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
createCompressor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
createConditionalWriter(String) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a ConditionalWriter connected to Accumulo.
createConditionalWriter(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createConditionalWriter(String, ConditionalWriterConfig) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a ConditionalWriter connected to Accumulo.
createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
Factory method to create a ConditionalWriter connected to Accumulo.
createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createDecompressionStream(InputStream, Decompressor, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
createDecompressor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
createDefaultFormatSupplier() - Static method in class org.apache.accumulo.core.util.format.DateFormatSupplier
Create a Supplier for FormatterConfig.DefaultDateFormats
createDeleteMutation(ReferenceFile) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Return an encoded delete marker Mutation to delete the specified TabletFile path.
CreateEmpty - Class in org.apache.accumulo.core.file.rfile
Create an empty RFile for use in recovering from data loss where Accumulo still refers internally to a path.
CreateEmpty() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty
 
CreateEmpty.IsSupportedCompressionAlgorithm - Class in org.apache.accumulo.core.file.rfile
 
CreateEmpty.NamedLikeRFile - Class in org.apache.accumulo.core.file.rfile
 
createEntry(Configuration, String, char[]) - Static method in class org.apache.accumulo.core.conf.HadoopCredentialProvider
Create a CredentialEntry using the configured Providers.
createExecutor(String, int) - Method in interface org.apache.accumulo.core.spi.compaction.ExecutorManager
Create a thread pool executor within a compaction service.
createExecutorService(AccumuloConfiguration, Property) - Method in class org.apache.accumulo.core.util.threads.ThreadPools
Create a thread pool based on a thread pool related property.
createExecutorService(AccumuloConfiguration, Property, boolean) - Method in class org.apache.accumulo.core.util.threads.ThreadPools
Create a thread pool based on a thread pool related property
createFactory() - Method in interface org.apache.accumulo.core.util.Retry.BuilderDone
Create a RetryFactory from this builder which can be used to create many Retry objects with the same settings.
createGeneralScheduledExecutorService(AccumuloConfiguration) - Method in class org.apache.accumulo.core.util.threads.ThreadPools
 
createHeap(int) - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
createInputStream(InputStream) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
createInputStream(InputStream, Decompressor) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
createInstanceFromPropertyName(AccumuloConfiguration, Property, Class<T>, T) - Static method in enum org.apache.accumulo.core.conf.Property
Creates a new instance of a class specified in a configuration property.
createLocalUser() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.createLocalUser
 
createLocalUser() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.createLocalUser
 
createLocalUser(String, PasswordToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Create a user
createLocalUser(String, PasswordToken) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
createLocalUser(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
createLocalUser(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
createLocalUser_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
createLocalUser_args(ClientService.createLocalUser_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
Performs a deep copy on other.
createLocalUser_args(TInfo, TCredentials, String, ByteBuffer) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
createLocalUser_call(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.createLocalUser_call
 
createLocalUser_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
createLocalUser_result(ClientService.createLocalUser_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
Performs a deep copy on other.
createLocalUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
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
 
createMetaStore(String) - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
createMultiTableBatchWriter() - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a Multi-Table BatchWriter.
createMultiTableBatchWriter() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createMultiTableBatchWriter(BatchWriterConfig) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a Multi-Table BatchWriter connected to Accumulo.
createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
Factory method to create a Multi-Table BatchWriter connected to Accumulo.
createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createMutation(String, long) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
Deprecated.
Creates the Mutation for the Order section for the given file and time
createNamedRunnable(String, Runnable) - Static method in class org.apache.accumulo.core.util.threads.Threads
 
createNoTabletServersProblem() - Method in class org.apache.accumulo.core.spi.balancer.util.ThrottledBalancerProblemReporter
Create a new problem reporter to indicate there are no tablet servers available and balancing could not be performed.
createOffline() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Create the new table in an offline state.
createOutputStream(OutputStream) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
createOutputStream(OutputStream, Compressor) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
createOutstandingMigrationsProblem() - Method in class org.apache.accumulo.core.spi.balancer.util.ThrottledBalancerProblemReporter
Create a new problem reporter to indicate that balancing could not be performed due to the existence of outstanding migrations.
createPlanBuilder() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
createPrevRowMutation(KeyExtent) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
Creates a mutation that encodes a KeyExtent as a prevRow entry.
createPriority(CompactionKind, int, int) - Static method in class org.apache.accumulo.core.util.compaction.CompactionJobPrioritizer
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
Deprecated.
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
Deprecated.
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloRowInputFormat
Deprecated.
 
createRetry() - Method in interface org.apache.accumulo.core.util.Retry.BuilderDone
Create a single Retry object with the currently configured builder settings.
createRetry() - Method in interface org.apache.accumulo.core.util.Retry.RetryFactory
Create a single Retry object from this factory's settings.
createScanner(String) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a Scanner with all of the user's authorizations.
createScanner(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createScanner(String, Authorizations) - Method in interface org.apache.accumulo.core.client.AccumuloClient
Factory method to create a Scanner connected to Accumulo.
createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
Factory method to create a Scanner connected to Accumulo.
createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
createScheduledExecutorService(int, String) - Method in class org.apache.accumulo.core.util.threads.ThreadPools
Create a named ScheduledThreadPool.
createSimpleFormatSupplier(String) - Static method in class org.apache.accumulo.core.util.format.DateFormatSupplier
Create a generator for SimpleDateFormats accepting a dateFormat
createSimpleFormatSupplier(String, TimeZone) - Static method in class org.apache.accumulo.core.util.format.DateFormatSupplier
Create a generator for SimpleDateFormats accepting a dateFormat
createTableInstanceFromPropertyName(AccumuloConfiguration, Property, Class<T>, T) - Static method in enum org.apache.accumulo.core.conf.Property
Creates a new instance of a class specified in a configuration property.
createTAuthIdentifier(String, int, long, long, String) - Static method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
createThread(String, Runnable) - Static method in class org.apache.accumulo.core.util.threads.Threads
 
createThread(String, OptionalInt, Runnable) - Static method in class org.apache.accumulo.core.util.threads.Threads
 
createThread(String, OptionalInt, Runnable, Thread.UncaughtExceptionHandler) - Static method in class org.apache.accumulo.core.util.threads.Threads
 
CreateToken - Class in org.apache.accumulo.core.util
 
CreateToken() - Constructor for class org.apache.accumulo.core.util.CreateToken
 
createTransport(HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a transport that is not pooled
CREATION_DATE - Enum constant in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
 
creationDate - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
CREDENTIAL_PROVIDERS_PROPERTY - Static variable in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
CredentialProviderToken - Class in org.apache.accumulo.core.client.security.tokens
An AuthenticationToken backed by a Hadoop CredentialProvider.
CredentialProviderToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
CredentialProviderToken(String, String) - Constructor for class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
credentials - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
credentials - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
credentials - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
credentials - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
credentials - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
credentials - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
credentials - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_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.chop_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_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.loadFiles_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_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.TabletScanClientService.getActiveScans_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
Credentials - Class in org.apache.accumulo.core.clientImpl
A wrapper for internal use.
Credentials(String, AuthenticationToken) - Constructor for class org.apache.accumulo.core.clientImpl.Credentials
Creates a new credentials object.
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
CREDENTIALS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
CryptoEnvironment - Interface in org.apache.accumulo.core.spi.crypto
Useful information provided to the crypto implementation
CryptoEnvironment.Scope - Enum in org.apache.accumulo.core.spi.crypto
Where in Accumulo the on-disk file encryption takes place.
CryptoEnvironmentImpl - Class in org.apache.accumulo.core.crypto
 
CryptoEnvironmentImpl(CryptoEnvironment.Scope) - Constructor for class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
 
CryptoEnvironmentImpl(CryptoEnvironment.Scope, TableId, byte[]) - Constructor for class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
Construct the crypto environment.
CryptoException() - Constructor for exception org.apache.accumulo.core.spi.crypto.CryptoService.CryptoException
 
CryptoException(String) - Constructor for exception org.apache.accumulo.core.spi.crypto.CryptoService.CryptoException
 
CryptoException(String, Throwable) - Constructor for exception org.apache.accumulo.core.spi.crypto.CryptoService.CryptoException
 
CryptoException(Throwable) - Constructor for exception org.apache.accumulo.core.spi.crypto.CryptoService.CryptoException
 
CryptoFactoryLoader - Class in org.apache.accumulo.core.crypto
 
CryptoFactoryLoader() - Constructor for class org.apache.accumulo.core.crypto.CryptoFactoryLoader
 
cryptoService - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
cryptoService(CryptoService) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
cryptoService(CryptoService) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
CryptoService - Interface in org.apache.accumulo.core.spi.crypto
A self-contained cryptographic service.
CryptoService.CryptoException - Exception in org.apache.accumulo.core.spi.crypto
Runtime Crypto exception
CryptoServiceFactory - Interface in org.apache.accumulo.core.spi.crypto
A Factory that returns a CryptoService based on the environment and configuration.
CryptoUtils - Class in org.apache.accumulo.core.crypto
 
CryptoUtils() - Constructor for class org.apache.accumulo.core.crypto.CryptoUtils
 
current - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
current - Variable in class org.apache.accumulo.core.metadata.TabletLocationState
 
current(String, String) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
current(TServerInstance) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
CURRENT - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ConfigurationType
 
CURRENT - Enum constant in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
CURRENT - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.LocationType
 
CURRENT_LOG - Enum constant in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
currentDocID - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
currentK - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
The Key that should be returned to the client
currentKey - Variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
currentKey - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
The Key that is used to determine progress in the current InputSplit.
CurrentLocationColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.CurrentLocationColumnFamily
 
currentLog - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
currentMigrations() - Method in class org.apache.accumulo.core.manager.balancer.BalanceParamsImpl
 
currentMigrations() - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer.BalanceParameters
 
currentPartition - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
currentStatus() - Method in class org.apache.accumulo.core.manager.balancer.AssignmentParamsImpl
 
currentStatus() - Method in class org.apache.accumulo.core.manager.balancer.BalanceParamsImpl
 
currentStatus() - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer.AssignmentParameters
 
currentStatus() - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer.BalanceParameters
 
currentTimeMillis() - Method in interface org.apache.accumulo.core.fate.AgeOffStore.TimeSource
 
currentV - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
The Value that should be return to the client
cv - Variable in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
CV - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
cve - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
CVE - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
 

D

data - Variable in class org.apache.accumulo.core.data.ArrayByteSequence
 
data - Variable in class org.apache.accumulo.core.dataImpl.ComparableBytes
 
data - Variable in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
data - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
data - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
DATA - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
DATA - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
 
DATA - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
 
DATA - Enum constant in enum org.apache.accumulo.core.spi.cache.CacheType
 
DATA_CACHE_HITS - Enum constant in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
 
DATA_CACHE_REQUEST - Enum constant in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
 
DATA_IBUF_SIZE - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
DATA_OBUF_SIZE - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
dataCacheHits - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
dataCacheRequest - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
DataFileColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.DataFileColumnFamily
 
DataFileValue - Class in org.apache.accumulo.core.metadata.schema
 
DataFileValue(byte[]) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
 
DataFileValue(long, long) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
 
DataFileValue(long, long, long) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
 
DataFileValue(String) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
 
DataoutputHasher - Class in org.apache.accumulo.core.sample.impl
 
DataoutputHasher(Hasher) - Constructor for class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
DATE_FORMAT - Static variable in class org.apache.accumulo.core.util.format.DateStringFormatter
Deprecated.
 
DateFormatSupplier - Class in org.apache.accumulo.core.util.format
DateFormatSupplier is a ThreadLocal<DateFormat> that will set the correct TimeZone when the object is retrieved by DateFormatSupplier.get().
DateFormatSupplier() - Constructor for class org.apache.accumulo.core.util.format.DateFormatSupplier
 
DateFormatSupplier(TimeZone) - Constructor for class org.apache.accumulo.core.util.format.DateFormatSupplier
 
DateLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for date objects.
DateLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.DateLexicoder
 
DateStringFormatter - Class in org.apache.accumulo.core.util.format
Deprecated.
since 1.8.0
DateStringFormatter() - Constructor for class org.apache.accumulo.core.util.format.DateStringFormatter
Deprecated.
 
DateStringFormatter(TimeZone) - Constructor for class org.apache.accumulo.core.util.format.DateStringFormatter
Deprecated.
 
DEAD_TABLET_SERVERS - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
DeadServer - Class in org.apache.accumulo.core.manager.thrift
 
DeadServer() - Constructor for class org.apache.accumulo.core.manager.thrift.DeadServer
 
DeadServer(String, long, String) - Constructor for class org.apache.accumulo.core.manager.thrift.DeadServer
 
DeadServer(DeadServer) - Constructor for class org.apache.accumulo.core.manager.thrift.DeadServer
Performs a deep copy on other.
DeadServer._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
deadTabletServers - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
DebugIterator - Class in org.apache.accumulo.core.iterators
 
DebugIterator() - Constructor for class org.apache.accumulo.core.iterators.DebugIterator
 
DebugIterator(String, SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.DebugIterator
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.AbstractEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.DateLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
 
decode(byte[]) - Method in interface org.apache.accumulo.core.client.lexicoder.Encoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.FloatLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.ListLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.PairLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.StringLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.TextLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
 
decode(byte[], int) - Static method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
decode(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.AbstractEncoder
Checks if the byte array is null, or if parameters exceed the bounds of the byte array, then calls AbstractEncoder.decodeUnchecked(byte[], int, int).
decode(byte[], UserCompactionUtils.Decoder<T>) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decode(DataInput) - Method in interface org.apache.accumulo.core.clientImpl.UserCompactionUtils.Decoder
 
decode(DataInput, int, int) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decode(CompactionConfig, DataInput) - Static method in class org.apache.accumulo.core.clientImpl.CompactionStrategyConfigUtil
 
decodeBase64FileName(String) - Static method in class org.apache.accumulo.core.util.Encoding
 
decodeBooleans(String) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
decodeColumnFamilies(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
decodeColumnFamily(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
decodeColumnFamily(Key, Value) - Static method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
Decode whole row/cf out of value.
decodeColumns(String) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
decodeColumns(String) - Static method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnSet
 
decodeCompactionConfig(byte[]) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decodeCompactionConfig(DataInput) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decodeConfigurer(byte[]) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decodeConfigurer(DataInput) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decodeIdentifier(String) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
Decode the encoded TokenIdentifier into bytes suitable to reconstitute the identifier.
decodeIteratorSettings(byte[]) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.SystemIteratorUtil
 
decodeMap(byte[]) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decodeMap(DataInput) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decodePrevEndRow(Value) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
 
decodeRow(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
 
decodeRow(Key, Value) - Static method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
decodeRow(Text) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
Decodes a metadata row into a pair of table ID and end row.
decodeSelector(byte[]) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decodeSelector(DataInput) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
decodeStatic(byte[], int, int) - Static method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
decodeToken(String, String) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.AbstractEncoder
Decodes a byte array without checking if the offset and len exceed the bounds of the actual array.
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
If offset == 0 and len == data.length, returns data.
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.DateLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.FloatLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.ListLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.LongLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.PairLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.ReverseLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.SequenceLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.StringLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.TextLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
 
decompress(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
decompress(ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.CompressedIterators
 
decompress(List<TKeyValue>) - Static method in class org.apache.accumulo.core.data.Key
Decompresses a list of key/value pairs received from thrift.
decrement(KT, long) - Method in class org.apache.accumulo.core.util.MapCounter
 
decryptStream(InputStream) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule.AESCBCFileDecrypter
 
decryptStream(InputStream) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule.AESGCMFileDecrypter
 
decryptStream(InputStream) - Method in interface org.apache.accumulo.core.spi.crypto.FileDecrypter
Decrypt the InputStream
decryptStream(InputStream) - Method in class org.apache.accumulo.core.spi.crypto.NoFileDecrypter
 
DeduplicatingLogger(Logger, Duration, long) - Constructor for class org.apache.accumulo.core.logging.ConditionalLogger.DeduplicatingLogger
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
deepCopy() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
deepCopy() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
deepCopy() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
deepCopy() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
deepCopy() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
deepCopy() - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
deepCopy() - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
deepCopy() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
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() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
deepCopy() - Method in exception org.apache.accumulo.core.manager.thrift.RecoveryException
 
deepCopy() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
deepCopy() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
deepCopy() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
deepCopy() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
deepCopy() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
deepCopy() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
deepCopy() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
deepCopy() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
deepCopy() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
deepCopy() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_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.TabletScanClientService.closeMultiScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
deepCopy() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Combiner
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DevNull
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Filter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ServerFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
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.SynchronizedServerFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.ColumnQualifierFilter
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.CountingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.MultiIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SampleIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.StatsIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.VisibilityFilter
 
DEFAULT - Enum constant in enum org.apache.accumulo.core.client.Durability
Use the durability as specified by the table or system configuration.
DEFAULT - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ConfigurationType
 
DEFAULT - Enum constant in enum org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment.Scope
 
DEFAULT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TDurability
 
DEFAULT - Static variable in class org.apache.accumulo.core.clientImpl.Namespace
 
DEFAULT_ACCEPTABLE_FACTOR - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
DEFAULT_COMPACTION_SERVICE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
DEFAULT_CONFIGURER - Static variable in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
DEFAULT_DOC_COLF - Static variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
DEFAULT_INDEX_COLF - Static variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
DEFAULT_LOAD_FACTOR - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
Backing Concurrent Map Configuration
DEFAULT_MEMORY_FACTOR - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
DEFAULT_MIN_FACTOR - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
Eviction thresholds
DEFAULT_MULTI_FACTOR - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
DEFAULT_POOL - Static variable in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
DEFAULT_SCAN_EXECUTOR_NAME - Static variable in class org.apache.accumulo.core.spi.scan.SimpleScanDispatcher
 
DEFAULT_SCAN_SERVER_GROUP_NAME - Static variable in interface org.apache.accumulo.core.spi.scan.ScanServerSelector
The scan server group name that will be used when one is not specified.
DEFAULT_SECURITY_ERROR - Enum constant in enum org.apache.accumulo.core.client.security.SecurityErrorCode
 
DEFAULT_SECURITY_ERROR - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
DEFAULT_SELECTOR - Static variable in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
DEFAULT_SERVICE - Static variable in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
DEFAULT_SINGLE_FACTOR - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
Priority buckets
DEFAULT_STRATEGY - Static variable in class org.apache.accumulo.core.clientImpl.CompactionStrategyConfigUtil
 
DEFAULT_TABLE_NAME - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.OutputConfigurator.WriteOpts
 
DEFAULT_TABLET_DIR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Initial tablet directory name for the default tablet in all tables
DEFAULT_TIMEOUT_MILLISECS - Static variable in class org.apache.accumulo.core.util.threads.ThreadPools
 
DEFAULT_VISIBILITY_CACHE_SIZE - Static variable in class org.apache.accumulo.core.Constants
 
DefaultCompactionPlanner - Class in org.apache.accumulo.core.spi.compaction
Finds the largest continuous set of small files that meet the compaction ratio and do not prevent future compactions.
DefaultCompactionPlanner() - Constructor for class org.apache.accumulo.core.spi.compaction.DefaultCompactionPlanner
 
DefaultConfiguration - Class in org.apache.accumulo.core.conf
An AccumuloConfiguration that contains only default values for properties.
DefaultContextClassLoaderFactory - Class in org.apache.accumulo.core.classloader
The default implementation of ContextClassLoaderFactory.
DefaultContextClassLoaderFactory(AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.classloader.DefaultContextClassLoaderFactory
 
DefaultDateFormat() - Constructor for class org.apache.accumulo.core.util.format.FormatterConfig.DefaultDateFormat
 
DefaultFormatter - Class in org.apache.accumulo.core.util.format
 
DefaultFormatter() - Constructor for class org.apache.accumulo.core.util.format.DefaultFormatter
 
DefaultKeySizeConstraint - Class in org.apache.accumulo.core.constraints
Deprecated.
since 2.1.0 Use DefaultKeySizeConstraint
DefaultKeySizeConstraint - Class in org.apache.accumulo.core.data.constraints
A constraints that limits the size of keys to 1mb.
DefaultKeySizeConstraint() - Constructor for class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
Deprecated.
 
DefaultKeySizeConstraint() - Constructor for class org.apache.accumulo.core.data.constraints.DefaultKeySizeConstraint
 
defaultNamespace() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Returns the name of the default namespace
defaultNamespace() - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
DefaultScanInterpreter - Class in org.apache.accumulo.core.util.interpret
Deprecated.
since 2.1.0 This will be removed in a future version in favor of JShell
DefaultScanInterpreter() - Constructor for class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
Deprecated.
 
defaultVisibility - Variable in class org.apache.accumulo.core.iteratorsImpl.system.VisibilityFilter
 
DEFAUT_GROUP_PROPERTY - Static variable in class org.apache.accumulo.core.spi.balancer.RegexGroupBalancer
 
delegate - Variable in class org.apache.accumulo.core.logging.ConditionalLogger
 
DelegatingChooser - Class in org.apache.accumulo.core.spi.fs
A VolumeChooser that delegates to another volume chooser based on other properties: table.custom.volume.chooser for tables, and general.custom.volume.chooser.scoped for scopes.
DelegatingChooser() - Constructor for class org.apache.accumulo.core.spi.fs.DelegatingChooser
 
DelegationToken - Interface in org.apache.accumulo.core.client.security.tokens
An AuthenticationToken that wraps a "Hadoop style" delegation token created by Accumulo.
DelegationTokenConfig - Class in org.apache.accumulo.core.client.admin
Configuration options for obtaining a delegation token created by SecurityOperations.getDelegationToken(DelegationTokenConfig)
DelegationTokenConfig() - Constructor for class org.apache.accumulo.core.client.admin.DelegationTokenConfig
 
DelegationTokenConfigSerializer - Class in org.apache.accumulo.core.clientImpl
Handles serialization of DelegationTokenConfig
DelegationTokenConfigSerializer() - Constructor for class org.apache.accumulo.core.clientImpl.DelegationTokenConfigSerializer
 
DelegationTokenImpl - Class in org.apache.accumulo.core.clientImpl
 
DelegationTokenImpl() - Constructor for class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
DelegationTokenImpl(byte[], AuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
DelegationTokenImpl(String, UserGroupInformation, AuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
DelegationTokenImpl(Token<? extends TokenIdentifier>, AuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
DelegationTokenStub - Class in org.apache.accumulo.core.clientImpl.mapreduce
Deprecated.
since 2.0.0
DelegationTokenStub(String) - Constructor for class org.apache.accumulo.core.clientImpl.mapreduce.DelegationTokenStub
Deprecated.
 
delete() - Method in interface org.apache.accumulo.core.client.BatchDeleter
delete() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchDeleter
 
delete() - Method in interface org.apache.accumulo.core.data.Mutation.MutationOptions
 
delete(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
delete(long) - Method in class org.apache.accumulo.core.fate.Fate
 
delete(long) - Method in interface org.apache.accumulo.core.fate.TStore
Remove the transaction from the store.
delete(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
delete(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Delete an empty namespace
delete(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Delete a table
delete(String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
delete(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
delete(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Delete the specified node, and ignore NONODE exceptions.
DELETE - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
DELETE_RANGE - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
DELETE_ROW_VALUE - Static variable in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
deleteBulkFile(TabletFile) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
deleted - Variable in class org.apache.accumulo.core.data.Key
 
deleted - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
deleted(boolean) - Method in interface org.apache.accumulo.core.data.KeyBuilder.Build
Set the deleted marker of the Key to the parameter.
DELETED - Enum constant in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
DELETED - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TUnloadTabletGoal
 
DELETED_FILES - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
deletedFiles - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
deleteExternalCompaction(ExternalCompactionId) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
deleteExternalCompactionFinalStates(Collection<ExternalCompactionId>) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
 
deleteFile(StoredTabletFile) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
deleteGcCandidates(Ample.DataLevel, Collection<GcCandidate>, Ample.GcCandidateType) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Enum added to support unique candidate deletions in 2.1
deleteLocation(TabletMetadata.Location) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
deleteLock(ZooReaderWriter, ServiceLock.ServiceLockPath) - Static method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
deleteLock(ZooReaderWriter, ServiceLock.ServiceLockPath, String) - Static method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
deleteLocks(ZooReaderWriter, ServiceLock.ServiceLockPath, String) - Method in class org.apache.accumulo.core.fate.AdminUtil
 
deleteRows(String, Text, Text) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Delete rows between (start, end]
deleteRows(String, Text, Text) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
DELETES_IGNORED_STAT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
This is the name of the statistic that tracks the total number of deleted keys seen.
DELETES_STAT - Static variable in class org.apache.accumulo.core.client.summary.summarizers.DeletesSummarizer
The name of the statistics for the number of deletes.
deleteScan(StoredTabletFile) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
deleteScanServerFileReferences(String, UUID) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Delete scan server references for this server
deleteScanServerFileReferences(Collection<ScanServerRefTabletFile>) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Delete the set of scan server references
DeletesSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
 
DeletesSummarizer - Class in org.apache.accumulo.core.client.summary.summarizers
This summarizer tracks the total number of delete Keys seen and the total number of keys seen.
DeletesSummarizer() - Constructor for class org.apache.accumulo.core.client.summary.summarizers.DeletesSummarizer
 
deleteStrict(String, int) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Delete the specified node if the version matches the provided version.
deleteSuspension() - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
deleteWal(String) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
deleteWal(LogEntry) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
DELETING - Enum constant in enum org.apache.accumulo.core.manager.state.tables.TableState
 
DeletingIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
 
DeletingIterator.Behavior - Enum in org.apache.accumulo.core.iteratorsImpl.system
 
DeprecatedPropertyUtil - Class in org.apache.accumulo.core.conf
 
DeprecatedPropertyUtil() - Constructor for class org.apache.accumulo.core.conf.DeprecatedPropertyUtil
 
DeprecatedPropertyUtil.PropertyRenamer - Class in org.apache.accumulo.core.conf
 
deprecatedSince() - Method in enum org.apache.accumulo.core.conf.Property
Gets the version in which the property was deprecated.
derive() - Method in interface org.apache.accumulo.core.conf.AccumuloConfiguration.Deriver
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.Combiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.Filter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.LongCombiner
 
describeOptions() - Method in interface org.apache.accumulo.core.iterators.OptionDescriber
Gets an iterator options object that contains information needed to configure this iterator.
describeOptions() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.MaxCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.MinCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ReqVisFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.SummingCombiner
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
describeOptions() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
description - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
description - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
description - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
description - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
description - Variable in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
description() - Method in class org.apache.accumulo.core.file.rfile.CreateEmpty
 
description() - Method in class org.apache.accumulo.core.file.rfile.GenerateSplits
 
description() - Method in class org.apache.accumulo.core.file.rfile.PrintInfo
 
description() - Method in class org.apache.accumulo.core.file.rfile.SplitLarge
 
description() - Method in class org.apache.accumulo.core.util.CreateToken
 
description() - Method in class org.apache.accumulo.core.util.Help
 
description() - Method in class org.apache.accumulo.core.util.Version
 
DESCRIPTION - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
 
DESCRIPTION - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
 
DESCRIPTION - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
DESCRIPTION - Enum constant in enum org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
 
deserialize(byte[], int, int, T) - Method in class org.apache.accumulo.core.util.ThriftMessageUtil
Deserializes a message into the provided instance from serialized
deserialize(byte[], T) - Method in class org.apache.accumulo.core.util.ThriftMessageUtil
Assumes the entire contents of the byte array compose the serialized instance
deserialize(Class<T>, byte[]) - Static method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
A convenience method to create tokens from serialized bytes, created by AuthenticationToken.AuthenticationTokenSerializer.serialize(AuthenticationToken)
deserialize(String) - Static method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
 
deserialize(String) - Static method in class org.apache.accumulo.core.clientImpl.Credentials
Converts the serialized form to an instance of Credentials.
deserialize(String, byte[]) - Static method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
An alternate version of AuthenticationToken.AuthenticationTokenSerializer.deserialize(Class, byte[]) that accepts a token class name rather than a token class.
deserialize(TDelegationTokenConfig) - Static method in class org.apache.accumulo.core.clientImpl.DelegationTokenConfigSerializer
Deserialize the Thrift delegation token config into the non-thrift variant
deserializeFetchedColumns(Collection<String>) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
 
destroy() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
destroy() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
 
destroy() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
destroy() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
destroy() - Method in class org.apache.accumulo.core.clientImpl.mapreduce.DelegationTokenStub
Deprecated.
 
DevNull - Class in org.apache.accumulo.core.iterators
An iterator that is useful testing...
DevNull() - Constructor for class org.apache.accumulo.core.iterators.DevNull
 
DIGEST_MD5 - Enum constant in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
 
DIGEST_MD5 - Static variable in class org.apache.accumulo.core.rpc.ThriftUtil
 
digestAuth(ZooKeeper, String) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
 
dir - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
DIR - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
DIR - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args._Fields
 
DIRECTORY_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
DIRECTORY_QUAL - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds the location of the tablet in the DFS file system
disable() - Method in interface org.apache.accumulo.core.singletons.SingletonService
 
DISABLED - Enum constant in enum org.apache.accumulo.core.spi.scan.ScanDispatch.CacheUsage
Do not use cache for this scan, possibly overriding table settings.
disableIsolation() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
disableIsolation() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
disableIsolation() - Method in interface org.apache.accumulo.core.client.Scanner
Disables row isolation.
disableIsolation() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
disableIsolation() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
DiscardCloseOutputStream - Class in org.apache.accumulo.core.crypto.streams
 
DiscardCloseOutputStream(OutputStream) - Constructor for class org.apache.accumulo.core.crypto.streams.DiscardCloseOutputStream
 
DiskUsage - Class in org.apache.accumulo.core.client.admin
 
DiskUsage(SortedSet<String>, long) - Constructor for class org.apache.accumulo.core.client.admin.DiskUsage
 
dispatch(CompactionDispatcher.DispatchParameters) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher
Accumulo calls this method for compactions to determine what service to use.
dispatch(CompactionDispatcher.DispatchParameters) - Method in class org.apache.accumulo.core.spi.compaction.SimpleCompactionDispatcher
 
dispatch(ScanDispatcher.DispatchParameters) - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher
Accumulo calls this method for each scan batch to determine what executor to use and how to utilize cache for the scan.
dispatch(ScanDispatcher.DispatchParameters) - Method in class org.apache.accumulo.core.spi.scan.SimpleScanDispatcher
 
dispatch(ScanDispatcher.DispatchParmaters) - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher
Deprecated.
since 2.1.0 please implement ScanDispatcher.dispatch(DispatchParameters) instead of this. Accumulo will only call ScanDispatcher.dispatch(DispatchParameters) directly, it will never call this. However the default implementation of ScanDispatcher.dispatch(DispatchParameters) calls this method.
DistributedCacheHelper - Class in org.apache.accumulo.core.clientImpl.mapreduce.lib
 
DistributedCacheHelper() - Constructor for class org.apache.accumulo.core.clientImpl.mapreduce.lib.DistributedCacheHelper
 
DistributedReadWriteLock - Class in org.apache.accumulo.core.fate.zookeeper
A ReadWriteLock that can be implemented in ZooKeeper.
DistributedReadWriteLock(DistributedReadWriteLock.QueueLock, byte[]) - Constructor for class org.apache.accumulo.core.fate.zookeeper.DistributedReadWriteLock
 
DistributedReadWriteLock.QueueLock - Interface in org.apache.accumulo.core.fate.zookeeper
 
doBulkFateOperation(List<ByteBuffer>, String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
docSource - Variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
doLookup(ClientContext, String, Map<KeyExtent, List<Range>>, Map<KeyExtent, List<Range>>, Map<KeyExtent, List<Range>>, TabletServerBatchReaderIterator.ResultReceiver, List<Column>, ScannerOptions, Authorizations) - Static method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReaderIterator
 
doNotLimitShowLength() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
 
DOSArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
DoubleLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for preserving the native Java sort order of Double values.
DoubleLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
 
drain(String) - Method in interface org.apache.accumulo.core.client.admin.ReplicationOperations
Deprecated.
Waits for a table to be fully replicated, given the state of files pending replication for the provided table at the point in time which this method is invoked.
drain(String) - Method in class org.apache.accumulo.core.clientImpl.ReplicationOperationsImpl
Deprecated.
 
drain(String, Set<String>) - Method in interface org.apache.accumulo.core.client.admin.ReplicationOperations
Deprecated.
Given the provided set of files that are pending replication for a table, wait for those files to be fully replicated to all configured peers.
drain(String, Set<String>) - Method in class org.apache.accumulo.core.clientImpl.ReplicationOperationsImpl
Deprecated.
 
drainReplicationTable() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.drainReplicationTable
 
drainReplicationTable() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.drainReplicationTable
 
drainReplicationTable(TInfo, TCredentials, String, Set<String>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
drainReplicationTable(TInfo, TCredentials, String, Set<String>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
drainReplicationTable(TInfo, TCredentials, String, Set<String>, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
drainReplicationTable(TInfo, TCredentials, String, Set<String>, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
drainReplicationTable_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
drainReplicationTable_args(ManagerClientService.drainReplicationTable_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
Performs a deep copy on other.
drainReplicationTable_args(TInfo, TCredentials, String, Set<String>) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
drainReplicationTable_call(TInfo, TCredentials, String, Set<String>, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.drainReplicationTable_call
 
drainReplicationTable_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
drainReplicationTable_result(boolean, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
drainReplicationTable_result(ManagerClientService.drainReplicationTable_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
Performs a deep copy on other.
DROP_NAMESPACE - Enum constant in enum org.apache.accumulo.core.security.NamespacePermission
 
DROP_NAMESPACE - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
DROP_TABLE - Enum constant in enum org.apache.accumulo.core.security.NamespacePermission
 
DROP_TABLE - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
DROP_TABLE - Enum constant in enum org.apache.accumulo.core.security.TablePermission
 
DROP_USER - Enum constant in enum org.apache.accumulo.core.security.SystemPermission
 
dropCacheBehind - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
dropCacheBehind(boolean) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
dropCachesBehind() - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
 
dropCachesBehind() - Method in class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
dropLocalUser() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
dropLocalUser() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.dropLocalUser
 
dropLocalUser(String) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Delete a user
dropLocalUser(String) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
dropLocalUser(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
dropLocalUser(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
dropLocalUser(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
dropLocalUser(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
dropLocalUser_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
dropLocalUser_args(ClientService.dropLocalUser_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
Performs a deep copy on other.
dropLocalUser_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
dropLocalUser_call(TInfo, TCredentials, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.dropLocalUser_call
 
dropLocalUser_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
dropLocalUser_result(ClientService.dropLocalUser_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
Performs a deep copy on other.
dropLocalUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
droppingOldTimestamp(long) - Method in class org.apache.accumulo.core.data.Mutation
 
duplicateReads() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
durability - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
durability - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
durability - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
Durability - Enum in org.apache.accumulo.core.client
The value for the durability of a BatchWriter or ConditionalWriter.
DURABILITY - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
DURABILITY - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
 
DURABILITY - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
 
DURABILITY - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
 
DurabilityImpl - Class in org.apache.accumulo.core.clientImpl
 
DurabilityImpl() - Constructor for class org.apache.accumulo.core.clientImpl.DurabilityImpl
 
duration - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
DurationFormat - Class in org.apache.accumulo.core.util
 
DurationFormat(long, String) - Constructor for class org.apache.accumulo.core.util.DurationFormat
 
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

e - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
e - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
e - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
E - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
 
E - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
 
E - Enum constant in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
 
ecid - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
ECOMP - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
edits - Variable in class org.apache.accumulo.core.replication.thrift.WalEdits
 
EDITS - Enum constant in enum org.apache.accumulo.core.replication.thrift.WalEdits._Fields
 
eid - Variable in class org.apache.accumulo.core.fate.zookeeper.ZooUtil.LockID
 
elapsed - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
ELAPSED - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
EMITTED_STAT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
This is the name of the statistic that tracks the total number of counter objects emitted by the CountingSummarizer.Converter.
empty() - Static method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
 
empty() - Static method in interface org.apache.accumulo.core.client.admin.ImportConfiguration
 
empty() - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
Build a SiteConfiguration that is initially empty with the option to override.
EMPTY - Enum constant in enum org.apache.accumulo.core.security.ColumnVisibility.NodeType
 
EMPTY - Static variable in interface org.apache.accumulo.core.client.admin.ImportConfiguration
 
EMPTY - Static variable in class org.apache.accumulo.core.constraints.Violations
 
EMPTY - Static variable in class org.apache.accumulo.core.security.Authorizations
An empty set of authorizations.
EMPTY - Static variable in class org.apache.accumulo.core.security.ColumnVisibility.Node
An empty list of nodes.
EMPTY_ITERATOR - Static variable in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
EmptyIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
 
EmptyIterator() - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
enable() - Method in interface org.apache.accumulo.core.singletons.SingletonService
 
enableAccumuloStart - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
ENABLED - Enum constant in enum org.apache.accumulo.core.spi.scan.ScanDispatch.CacheUsage
Use cache for this can, possibly overriding table settings.
enableIsolation() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
enableIsolation() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
enableIsolation() - Method in interface org.apache.accumulo.core.client.Scanner
Enables row isolation.
enableIsolation() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
enableIsolation() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
enableSampling(SamplerConfiguration) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Enable building a sample data set on the new table using the given sampler configuration.
enableSummarization(SummarizerConfiguration...) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Enables creating summary statistics using Summarizer's for the new table.
enableThreadPoolMetrics() - Method in class org.apache.accumulo.core.util.threads.ThreadPools.ThreadPoolExecutorBuilder
When set to true will emit metrics and register the metrics in a registry.
enableThreadPoolMetrics(boolean) - Method in class org.apache.accumulo.core.util.threads.ThreadPools.ThreadPoolExecutorBuilder
Optionally set to register pool metrics.
enableYielding(YieldCallback<K>) - Method in interface org.apache.accumulo.core.iterators.YieldingKeyValueIterator
Allows implementations to preempt further iteration of this iterator in the current RPC.
enableYielding(YieldCallback<Key>) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
encode() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
encode() - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
encode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
 
encode(DataOutput, int, int, String, Map<String, String>) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encode(DataOutput, Map<String, String>) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encode(DataOutput, CompactionConfig) - Static method in class org.apache.accumulo.core.clientImpl.CompactionStrategyConfigUtil
 
encode(DataOutput, CompactionConfig) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encode(DataOutput, T) - Method in interface org.apache.accumulo.core.clientImpl.UserCompactionUtils.Encoder
 
encode(Double) - Method in class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
 
encode(Float) - Method in class org.apache.accumulo.core.client.lexicoder.FloatLexicoder
 
encode(Integer) - Method in class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
 
encode(Integer) - Method in class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
 
encode(Long) - Method in class org.apache.accumulo.core.client.lexicoder.LongLexicoder
 
encode(Long) - Method in class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
 
encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
 
encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
 
encode(String) - Method in class org.apache.accumulo.core.client.lexicoder.StringLexicoder
 
encode(BigDecimal) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
 
encode(BigInteger) - Method in class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
 
encode(Date) - Method in class org.apache.accumulo.core.client.lexicoder.DateLexicoder
 
encode(List<E>) - Method in class org.apache.accumulo.core.client.lexicoder.SequenceLexicoder
encode(List<Long>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
 
encode(List<LT>) - Method in class org.apache.accumulo.core.client.lexicoder.ListLexicoder
encode(List<V>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
encode(Map<String, String>) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encode(UUID) - Method in class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
encode(CompactionConfig) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encode(ComparablePair<A, B>) - Method in class org.apache.accumulo.core.client.lexicoder.PairLexicoder
 
encode(Text) - Method in class org.apache.accumulo.core.client.lexicoder.TextLexicoder
 
encode(T) - Method in interface org.apache.accumulo.core.client.lexicoder.Encoder
 
encode(T) - Method in class org.apache.accumulo.core.client.lexicoder.ReverseLexicoder
 
encode(T, UserCompactionUtils.Encoder<T>) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encodeAsBase64FileName(byte[]) - Static method in class org.apache.accumulo.core.util.Encoding
 
encodeAsString() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
encodeAsValue() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
encodeBooleans(boolean[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
encodeColumnFamilies(Set<Text>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
encodeColumnFamily(List<Key>, List<Value>) - Static method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
Encode row/cf.
encodeColumnFamily(ByteSequence) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
encodeColumns(Text[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
encodeColumns(Text, Text) - Static method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnSet
 
encodeConfigurer(DataOutput, PluginConfig) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encodeConfigurer(PluginConfig) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encodeIdentifier(byte[]) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
Encode the serialized TokenIdentifier into a String.
encodeIteratorSettings(List<IteratorSetting>) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.SystemIteratorUtil
 
encodeIteratorSettings(IteratorConfig) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.SystemIteratorUtil
 
encodePassword(byte[]) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
Encode the token password into a character array.
encodePrevEndRow(Text) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
 
encoder() - Method in class org.apache.accumulo.core.client.summary.CountingSummarizer
 
Encoder<T> - Interface in org.apache.accumulo.core.client.lexicoder
An encoder represents a typed object that can be encoded/decoded to/from a byte array.
encodeRow(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
 
encodeRow(List<Key>, List<Value>) - Static method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
encodeRow(TableId, Text) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
encodeSelector(DataOutput, PluginConfig) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encodeSelector(PluginConfig) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
encodeToken(AuthenticationToken) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
Encoding - Class in org.apache.accumulo.core.util
 
Encoding() - Constructor for class org.apache.accumulo.core.util.Encoding
 
ENCODING - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
ENCODING_DEFAULT - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
ENCRYPT_ENABLED_PROPERTY - Static variable in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
encryptStream(OutputStream) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule.AESCBCFileEncrypter
 
encryptStream(OutputStream) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule.AESGCMFileEncrypter
 
encryptStream(OutputStream) - Method in interface org.apache.accumulo.core.spi.crypto.FileEncrypter
Encrypt the OutputStream.
encryptStream(OutputStream) - Method in class org.apache.accumulo.core.spi.crypto.NoFileEncrypter
 
end() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
end() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
END - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
END_BOUND - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
END_INCL - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
END_INCLUSIVE - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
END_ROW - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
 
END_ROW - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
 
END_ROW - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
END_ROW - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
 
END_ROW - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
 
endRow - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
endRow - Variable in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
endRow - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
endRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
endRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
endRow() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Returns this extent's end row
endRow(CharSequence) - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
The end row is inclusive.
endRow(CharSequence) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryOptions
 
endRow(Text) - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
The end row is inclusive.
endRow(Text) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryOptions
Summary data may possibly be stored at a more granular level than the entire file.
ensureNonOverlappingGroups(Map<String, Set<Text>>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
ensureRunning(ScheduledFuture<?>, String) - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
 
entries - Variable in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
entries - Variable in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
entries - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
ENTRIES - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
ENTRIES - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
 
ENTRIES - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args._Fields
 
ENTRIES_READ - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
ENTRIES_READ - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
ENTRIES_READ - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
 
ENTRIES_TO_BE_COMPACTED - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
ENTRIES_WRITTEN - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
ENTRIES_WRITTEN - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
ENTRIES_WRITTEN - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
 
entriesRead - Variable in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
entriesRead - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
entriesRead - Variable in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
entriesToBeCompacted - Variable in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
entriesWritten - Variable in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
entriesWritten - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
entriesWritten - Variable in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
EntryLengthSummarizer - Class in org.apache.accumulo.core.client.summary.summarizers
Summarizer that computes summary information about field lengths.
EntryLengthSummarizer() - Constructor for class org.apache.accumulo.core.client.summary.summarizers.EntryLengthSummarizer
 
entrySet() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
enumToConfKey(Class<?>, Enum<?>) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
Provides a configuration key for a given feature enum, prefixed by the implementingClass
enumToConfKey(Enum<?>) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
Provides a configuration key for a given feature enum.
env(IteratorEnvironment) - Method in interface org.apache.accumulo.core.iteratorsImpl.IteratorBuilder.IteratorBuilderEnv
Set the iteratorEnvironment.
env(IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.IteratorBuilderImpl
 
environment - Variable in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
environment - Variable in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
environment - Variable in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
equals(Object) - Method in class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
Deprecated.
 
equals(Object) - Method in class org.apache.accumulo.core.client.admin.DelegationTokenConfig
 
equals(Object) - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
equals(Object) - Method in class org.apache.accumulo.core.client.admin.PluginConfig
 
equals(Object) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
equals(Object) - Method in class org.apache.accumulo.core.client.IteratorSetting
 
equals(Object) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Deprecated.
 
equals(Object) - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
 
equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
equals(Object) - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
Compares the classname and options to determine equality.
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.Credentials
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocation
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
equals(Object) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
equals(Object) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
equals(Object) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
equals(Object) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
equals(Object) - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
equals(Object) - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
equals(Object) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
equals(Object) - Method in class org.apache.accumulo.core.data.AbstractId
AbstractID objects are considered equal if, and only if, they are of the same type and have the same canonical identifier.
equals(Object) - Method in class org.apache.accumulo.core.data.ByteSequence
 
equals(Object) - Method in class org.apache.accumulo.core.data.Column
 
equals(Object) - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
equals(Object) - Method in class org.apache.accumulo.core.data.Condition
 
equals(Object) - Method in class org.apache.accumulo.core.data.ConditionalMutation
 
equals(Object) - Method in class org.apache.accumulo.core.data.Key
 
equals(Object) - Method in class org.apache.accumulo.core.data.Mutation
 
equals(Object) - Method in class org.apache.accumulo.core.data.Range
 
equals(Object) - Method in class org.apache.accumulo.core.data.Value
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
equals(Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
equals(Object) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
equals(Object) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
 
equals(Object) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
equals(Object) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
equals(Object) - Method in class org.apache.accumulo.core.gc.GcCandidate
 
equals(Object) - Method in class org.apache.accumulo.core.gc.ReferenceFile
 
equals(Object) - 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(Object) - 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(Object) - Method in class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
equals(Object) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnUtil.ColFamHashKey
 
equals(Object) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnUtil.ColHashKey
 
equals(Object) - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
equals(Object) - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
equals(Object) - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
equals(Object) - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
equals(Object) - Method in exception org.apache.accumulo.core.manager.thrift.RecoveryException
 
equals(Object) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
equals(Object) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
equals(Object) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.SuspendingTServer
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.TabletFile
 
equals(Object) - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
equals(Object) - Method in class org.apache.accumulo.core.replication.ReplicationTarget
Deprecated.
 
equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
equals(Object) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
equals(Object) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
equals(Object) - Method in class org.apache.accumulo.core.rpc.SaslClientDigestCallbackHandler
 
equals(Object) - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
equals(Object) - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
equals(Object) - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
equals(Object) - Method in class org.apache.accumulo.core.security.Authorizations
 
equals(Object) - Method in class org.apache.accumulo.core.security.ColumnVisibility
equals(Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
equals(Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
equals(Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
equals(Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
equals(Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
equals(Object) - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
equals(Object) - 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(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
equals(Object) - 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(Object) - 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(Object) - 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(Object) - 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(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
equals(Object) - 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(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result
 
equals(Object) - 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(Object) - 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(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
equals(Object) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
equals(Object) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
equals(Object) - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
equals(Object) - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
equals(Object) - Method in class org.apache.accumulo.core.util.HostAndPort
 
equals(Object) - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
 
equals(Object) - Method in class org.apache.accumulo.core.util.Pair
 
equals(Object) - Method in class org.apache.accumulo.core.util.ServerServices
 
equals(Object) - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
equals(ClientService.authenticate_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
equals(ClientService.authenticate_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
equals(ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
equals(ClientService.authenticateUser_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
equals(ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
equals(ClientService.bulkImportFiles_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
equals(ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
equals(ClientService.changeAuthorizations_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
equals(ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
equals(ClientService.changeLocalUserPassword_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
equals(ClientService.checkClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
equals(ClientService.checkClass_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
equals(ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
equals(ClientService.checkNamespaceClass_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
equals(ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
equals(ClientService.checkTableClass_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
equals(ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
equals(ClientService.createLocalUser_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
equals(ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
equals(ClientService.dropLocalUser_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
equals(ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
equals(ClientService.getConfiguration_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
equals(ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
equals(ClientService.getDiskUsage_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
equals(ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
equals(ClientService.getInstanceId_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
equals(ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
equals(ClientService.getNamespaceConfiguration_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
equals(ClientService.getNamespaceProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
equals(ClientService.getNamespaceProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
equals(ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
equals(ClientService.getRootTabletLocation_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
equals(ClientService.getSystemProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
equals(ClientService.getSystemProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
equals(ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
equals(ClientService.getTableConfiguration_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
equals(ClientService.getTableProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
equals(ClientService.getTableProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
equals(ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
equals(ClientService.getUserAuthorizations_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
equals(ClientService.getVersionedNamespaceProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
equals(ClientService.getVersionedNamespaceProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
equals(ClientService.getVersionedSystemProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
equals(ClientService.getVersionedSystemProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
equals(ClientService.getVersionedTableProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
equals(ClientService.getVersionedTableProperties_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
equals(ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
equals(ClientService.getZooKeepers_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
equals(ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
equals(ClientService.grantNamespacePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
equals(ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
equals(ClientService.grantSystemPermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
equals(ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
equals(ClientService.grantTablePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
equals(ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
equals(ClientService.hasNamespacePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
equals(ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
equals(ClientService.hasSystemPermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
equals(ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
equals(ClientService.hasTablePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
equals(ClientService.isActive_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
equals(ClientService.isActive_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
equals(ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
equals(ClientService.listLocalUsers_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
equals(ClientService.ping_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
equals(ClientService.ping_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
equals(ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
equals(ClientService.revokeNamespacePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
equals(ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
equals(ClientService.revokeSystemPermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
equals(ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
equals(ClientService.revokeTablePermission_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
equals(TDiskUsage) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
equals(ThriftConcurrentModificationException) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
equals(ThriftNotActiveServiceException) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
equals(ThriftSecurityException) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
equals(ThriftTableOperationException) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
equals(ThriftTest.fails_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
equals(ThriftTest.fails_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
equals(ThriftTest.success_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
equals(ThriftTest.success_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
equals(ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
equals(ThriftTest.throwsError_result) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
equals(TVersionedProperties) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
equals(CompactionCoordinatorService.cancel_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
equals(CompactionCoordinatorService.cancel_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
equals(CompactionCoordinatorService.compactionCompleted_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
equals(CompactionCoordinatorService.compactionCompleted_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
equals(CompactionCoordinatorService.compactionFailed_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
equals(CompactionCoordinatorService.compactionFailed_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
equals(CompactionCoordinatorService.getCompactionJob_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
equals(CompactionCoordinatorService.getCompactionJob_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
equals(CompactionCoordinatorService.getCompletedCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
equals(CompactionCoordinatorService.getCompletedCompactions_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
equals(CompactionCoordinatorService.getRunningCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
equals(CompactionCoordinatorService.getRunningCompactions_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
equals(CompactionCoordinatorService.updateCompactionStatus_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
equals(CompactionCoordinatorService.updateCompactionStatus_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
equals(CompactorService.cancel_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
equals(CompactorService.cancel_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
equals(CompactorService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
equals(CompactorService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
equals(CompactorService.getRunningCompaction_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
equals(CompactorService.getRunningCompaction_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
equals(CompactorService.getRunningCompactionId_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
equals(CompactorService.getRunningCompactionId_result) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
equals(TCompactionStatusUpdate) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
equals(TExternalCompaction) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
equals(TExternalCompactionList) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
equals(TNextCompactionJob) - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
equals(UnknownCompactionIdException) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
equals(Column) - Method in class org.apache.accumulo.core.data.Column
Checks if this column equals another.
equals(Key, PartialKey) - Method in class org.apache.accumulo.core.data.Key
Compares part of a key.
equals(Mutation) - Method in class org.apache.accumulo.core.data.Mutation
Checks if this mutation equals another.
equals(Mutation) - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
 
equals(Range) - Method in class org.apache.accumulo.core.data.Range
Determines if this range equals another.
equals(InitialMultiScan) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
equals(InitialScan) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
equals(IterInfo) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
equals(MapFileInfo) - Method in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
equals(MultiScanResult) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
equals(ScanResult) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
equals(TCMResult) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
equals(TColumn) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
equals(TCondition) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
equals(TConditionalMutation) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
equals(TConditionalSession) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
equals(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
equals(TKey) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
equals(TKeyExtent) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
equals(TKeyValue) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
equals(TMutation) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
equals(TRange) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
equals(TRowRange) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
equals(TSummaries) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
equals(TSummarizerConfiguration) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
equals(TSummary) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
equals(TSummaryRequest) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
equals(UpdateErrors) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
equals(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
equals(GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
equals(GCMonitorService.getStatus_result) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
equals(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
equals(ColumnUtil.ColFamHashKey) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnUtil.ColFamHashKey
 
equals(ColumnUtil.ColHashKey) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnUtil.ColHashKey
 
equals(DeadServer) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
equals(FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
equals(FateService.beginFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
equals(FateService.cancelFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
equals(FateService.cancelFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
equals(FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
equals(FateService.executeFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
equals(FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
equals(FateService.finishFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
equals(FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
equals(FateService.waitForFateOperation_result) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
equals(ManagerClientService.drainReplicationTable_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
equals(ManagerClientService.drainReplicationTable_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
equals(ManagerClientService.getActiveTservers_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
equals(ManagerClientService.getActiveTservers_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
equals(ManagerClientService.getDelegationToken_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
equals(ManagerClientService.getDelegationToken_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
equals(ManagerClientService.getManagerStats_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
equals(ManagerClientService.getManagerStats_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
equals(ManagerClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
equals(ManagerClientService.initiateFlush_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
equals(ManagerClientService.modifyNamespaceProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
equals(ManagerClientService.modifyNamespaceProperties_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
equals(ManagerClientService.modifySystemProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
equals(ManagerClientService.modifySystemProperties_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
equals(ManagerClientService.modifyTableProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
equals(ManagerClientService.modifyTableProperties_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
equals(ManagerClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
equals(ManagerClientService.removeNamespaceProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
equals(ManagerClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
equals(ManagerClientService.removeSystemProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
equals(ManagerClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
equals(ManagerClientService.removeTableProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
equals(ManagerClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
equals(ManagerClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
equals(ManagerClientService.setManagerGoalState_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
equals(ManagerClientService.setManagerGoalState_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
equals(ManagerClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
equals(ManagerClientService.setNamespaceProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
equals(ManagerClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
equals(ManagerClientService.setSystemProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
equals(ManagerClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
equals(ManagerClientService.setTableProperty_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
equals(ManagerClientService.shutdown_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
equals(ManagerClientService.shutdown_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
equals(ManagerClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
equals(ManagerClientService.shutdownTabletServer_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
equals(ManagerClientService.waitForBalance_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
equals(ManagerClientService.waitForBalance_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
equals(ManagerClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
equals(ManagerClientService.waitForFlush_result) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
equals(ManagerMonitorInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
equals(RecoveryException) - Method in exception org.apache.accumulo.core.manager.thrift.RecoveryException
 
equals(TabletSplit) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
equals(ThriftPropertyException) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
equals(BulkImportStatus) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
equals(Compacting) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
equals(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
equals(TableInfo) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
equals(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
equals(KeyValues) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
equals(RemoteReplicationException) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
equals(ReplicationCoordinator.getServicerAddress_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
equals(ReplicationCoordinator.getServicerAddress_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
equals(ReplicationCoordinatorException) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
equals(ReplicationServicer.replicateKeyValues_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
equals(ReplicationServicer.replicateKeyValues_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
equals(ReplicationServicer.replicateLog_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
equals(ReplicationServicer.replicateLog_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
equals(WalEdits) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
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(TAuthenticationKey) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
equals(TAuthenticationTokenIdentifier) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
equals(TCredentials) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
equals(TDelegationToken) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
equals(TDelegationTokenConfig) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
equals(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
equals(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
equals(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
equals(ConstraintViolationException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
equals(InputFile) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
equals(IteratorConfig) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
equals(NoSuchScanIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
equals(NotServingTabletException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
equals(ScanServerBusyException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException
 
equals(TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
equals(TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
equals(TabletClientService.bulkImport_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
equals(TabletClientService.cancelUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
equals(TabletClientService.cancelUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
equals(TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
equals(TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
equals(TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
equals(TabletClientService.closeUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
equals(TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
equals(TabletClientService.compactionJobFailed_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
equals(TabletClientService.compactionJobFinished_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
equals(TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
equals(TabletClientService.conditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
equals(TabletClientService.contiuneGetSummaries_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
equals(TabletClientService.contiuneGetSummaries_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
equals(TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
equals(TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
equals(TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
equals(TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
equals(TabletClientService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
equals(TabletClientService.getActiveLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
equals(TabletClientService.getActiveLogs_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
equals(TabletClientService.getCompactionQueueInfo_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
equals(TabletClientService.getCompactionQueueInfo_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
equals(TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
equals(TabletClientService.getHistoricalStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
equals(TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
equals(TabletClientService.getTabletServerStatus_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
equals(TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
equals(TabletClientService.getTabletStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
equals(TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
equals(TabletClientService.halt_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
equals(TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
equals(TabletClientService.invalidateConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
equals(TabletClientService.loadFiles_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
equals(TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
equals(TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
equals(TabletClientService.reserveCompactionJob_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
equals(TabletClientService.reserveCompactionJob_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
equals(TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
equals(TabletClientService.splitTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
equals(TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
equals(TabletClientService.startConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
equals(TabletClientService.startGetSummaries_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
equals(TabletClientService.startGetSummaries_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
equals(TabletClientService.startGetSummariesForPartition_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
equals(TabletClientService.startGetSummariesForPartition_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
equals(TabletClientService.startGetSummariesFromFiles_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
equals(TabletClientService.startGetSummariesFromFiles_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result
 
equals(TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
equals(TabletClientService.startUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
equals(TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
equals(TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
equals(TabletClientService.update_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
equals(TabletScanClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
equals(TabletScanClientService.closeMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
equals(TabletScanClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
equals(TabletScanClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
equals(TabletScanClientService.continueMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
equals(TabletScanClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
equals(TabletScanClientService.continueScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
equals(TabletScanClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
equals(TabletScanClientService.getActiveScans_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
equals(TabletScanClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
equals(TabletScanClientService.startMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
equals(TabletScanClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
equals(TabletScanClientService.startScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
equals(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
equals(TCompactionQueueSummary) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
equals(TCompactionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
equals(TExternalCompactionJob) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
equals(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
equals(TooManyFilesException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
equals(TSampleNotPresentException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
equals(TSamplerConfiguration) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
equals(TInfo) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
equals(Text, Text) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
ERROR - Enum constant in enum org.apache.accumulo.core.spi.scan.ScanServerAttempt.Result
 
ERROR_DIR - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args._Fields
 
errorDir - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
errors - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
ERRORS - Enum constant in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
EscalatingLogger(Logger, Duration, long, Level) - Constructor for class org.apache.accumulo.core.logging.ConditionalLogger.EscalatingLogger
 
escape(byte[]) - Static method in class org.apache.accumulo.core.clientImpl.lexicoder.ByteUtils
Escapes 0x00 with 0x01 0x01 and 0x01 with 0x01 0x02
escape(byte[], boolean) - Static method in class org.apache.accumulo.core.security.VisibilityEvaluator
Properly escapes an authorization string.
ESTIMATED_SIZE - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.MapFileInfo._Fields
 
estimatedMemoryUsed() - Method in class org.apache.accumulo.core.data.Mutation
Gets an estimate of the amount of memory used by this mutation.
estimatedSize - Variable in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
estimateOverlappingEntries(KeyExtent) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
estimateOverlappingEntries(KeyExtent) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
Returns an estimate of the number of entries that overlap the given extent.
estimateOverlappingEntries(KeyExtent) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
estimateOverlappingEntries(KeyExtent) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
estimateOverlappingEntries(KeyExtent) - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
estimateOverlappingEntries(KeyExtent) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
estimateSizes(AccumuloConfiguration, Path, long, Collection<KeyExtent>, FileSystem, Cache<String, Long>, CryptoService) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
evaluate(ColumnVisibility) - Method in class org.apache.accumulo.core.security.VisibilityEvaluator
Evaluates the given column visibility against the authorizations provided to this evaluator.
EVENTUAL - Enum constant in enum org.apache.accumulo.core.client.ScannerBase.ConsistencyLevel
 
EVENTUAL - Enum constant in enum org.apache.accumulo.core.metadata.schema.Ample.ReadConsistency
Read data in a way that may be faster but may yield out of date data.
evict() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
evictBlock(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
evicted() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
evicted(AtomicLong) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
evictedPerEviction() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
EVICTION_THREAD_PROPERTY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
ex - Variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
EX - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
 
exact(CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row.
exact(CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row and column family.
exact(CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, and column qualifier.
exact(CharSequence, CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, column qualifier, and column visibility.
exact(CharSequence, CharSequence, CharSequence, CharSequence, long) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, column qualifier, column visibility, and timestamp.
exact(Text) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row.
exact(Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row and column family.
exact(Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, and column qualifier.
exact(Text, Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, column qualifier, and column visibility.
exact(Text, Text, Text, Text, long) - Static method in class org.apache.accumulo.core.data.Range
Creates a range that covers an exact row, column family, column qualifier, column visibility, and timestamp.
EXCEPTION - Enum constant in enum org.apache.accumulo.core.fate.Fate.TxInfo
 
execute(C) - Method in interface org.apache.accumulo.core.rpc.clients.ThriftClientTypes.Exec
 
execute(C) - Method in interface org.apache.accumulo.core.rpc.clients.ThriftClientTypes.ExecVoid
 
execute(String[]) - Method in class org.apache.accumulo.core.file.rfile.CreateEmpty
 
execute(String[]) - Method in class org.apache.accumulo.core.file.rfile.GenerateSplits
 
execute(String[]) - Method in class org.apache.accumulo.core.file.rfile.PrintInfo
 
execute(String[]) - Method in class org.apache.accumulo.core.file.rfile.SplitLarge
 
execute(String[]) - Method in class org.apache.accumulo.core.util.CreateToken
 
execute(String[]) - Method in class org.apache.accumulo.core.util.Help
 
execute(String[]) - Method in class org.apache.accumulo.core.util.Version
 
execute(ClientContext, ThriftClientTypes.Exec<R, C>) - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
execute(ClientContext, ThriftClientTypes.Exec<R, ClientService.Client>) - Method in class org.apache.accumulo.core.rpc.clients.ClientServiceThriftClient
 
execute(ClientContext, ThriftClientTypes.Exec<R, ManagerClientService.Client>) - Method in class org.apache.accumulo.core.rpc.clients.ManagerThriftClient
 
execute(ClientContext, ThriftClientTypes.Exec<R, ReplicationCoordinator.Client>) - Method in class org.apache.accumulo.core.rpc.clients.ReplicationCoordinatorThriftClient
 
execute(ClientContext, ThriftClientTypes.Exec<R, TabletClientService.Client>) - Method in class org.apache.accumulo.core.rpc.clients.TabletServerThriftClient
 
execute(Logger, ClientContext, ThriftClientTypes.Exec<R, C>) - Method in interface org.apache.accumulo.core.rpc.clients.TServerClient
 
executeCall(Long, Repo<T>) - Method in class org.apache.accumulo.core.fate.Fate
 
executeCleanupTask(Runnable) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
executeFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.executeFateOperation
 
executeFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Processor.executeFateOperation
 
executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.Iface
 
executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient
 
executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.AsyncIface
 
executeFateOperation_args() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
executeFateOperation_args(FateService.executeFateOperation_args) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
Performs a deep copy on other.
executeFateOperation_args(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
executeFateOperation_call(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.executeFateOperation_call
 
executeFateOperation_result() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
executeFateOperation_result(ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
executeFateOperation_result(FateService.executeFateOperation_result) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
Performs a deep copy on other.
executeIsReady(Long, Repo<T>) - Method in class org.apache.accumulo.core.fate.Fate
 
executeTableCommand(ClientContext, ThriftClientTypes.Exec<R, ManagerClientService.Client>) - Method in class org.apache.accumulo.core.rpc.clients.ManagerThriftClient
 
executeVoid(ClientContext, ThriftClientTypes.ExecVoid<C>) - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
executeVoid(ClientContext, ThriftClientTypes.ExecVoid<ClientService.Client>) - Method in class org.apache.accumulo.core.rpc.clients.ClientServiceThriftClient
 
executeVoid(ClientContext, ThriftClientTypes.ExecVoid<ManagerClientService.Client>) - Method in class org.apache.accumulo.core.rpc.clients.ManagerThriftClient
 
executeVoid(ClientContext, ThriftClientTypes.ExecVoid<TabletClientService.Client>) - Method in class org.apache.accumulo.core.rpc.clients.TabletServerThriftClient
 
executeVoid(Logger, ClientContext, ThriftClientTypes.ExecVoid<C>) - Method in interface org.apache.accumulo.core.rpc.clients.TServerClient
 
executeVoidTableCommand(ClientContext, ThriftClientTypes.ExecVoid<ManagerClientService.Client>) - Method in class org.apache.accumulo.core.rpc.clients.ManagerThriftClient
 
EXECUTION_HINTS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
EXECUTION_HINTS - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
ExecutionError(String, Throwable) - Constructor for error org.apache.accumulo.core.util.threads.ThreadPools.ExecutionError
 
executionHints - Variable in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
executionHints - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
executionHints - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
executor(Executor) - Method in interface org.apache.accumulo.core.client.admin.TableOperations.ImportMappingOptions
Files are examined to determine where to load them.
executor(Executor) - Method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
ExecutorManager - Interface in org.apache.accumulo.core.spi.compaction
Offered to a Compaction Planner at initialization time so it can create executors.
EXISTING_NAMESPACE_NAME - Static variable in class org.apache.accumulo.core.util.Validators
 
EXISTING_TABLE_NAME - Static variable in class org.apache.accumulo.core.util.Validators
 
exists(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
A method to check if a namespace exists in Accumulo.
exists(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
A method to check if a table exists in Accumulo.
exists(String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
exists(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
exists(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
exists(String, Watcher) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
exists(ClientContext, NamespaceId) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
 
EXISTS - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
exit(int) - Method in class org.apache.accumulo.core.cli.Help
 
exitWithError(String, int) - Method in class org.apache.accumulo.core.cli.Help
 
EXPIRATION_DATE - Enum constant in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
 
EXPIRATION_DATE - Enum constant in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
expirationDate - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
expirationDate - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
EXPORT - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
EXPORT_FILE - Static variable in class org.apache.accumulo.core.Constants
 
EXPORT_INFO_FILE - Static variable in class org.apache.accumulo.core.Constants
 
EXPORT_METADATA_FILE - Static variable in class org.apache.accumulo.core.Constants
 
EXPORT_TABLE_CONFIG_FILE - Static variable in class org.apache.accumulo.core.Constants
 
exportTable(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Exports a table.
exportTable(String, String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
EXTENSION - Static variable in class org.apache.accumulo.core.file.rfile.RFile
 
extent - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
extent - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
extent - Variable in class org.apache.accumulo.core.metadata.TabletLocationState
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
extent - Variable in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
extent - Variable in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
extent - Variable in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
EXTENT - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
 
EXTENT - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
 
EXTENT - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args._Fields
 
EXTERNAL_COMPACTION_ID - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
ExternalCompactionColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ExternalCompactionColumnFamily
 
ExternalCompactionFinalState - Class in org.apache.accumulo.core.metadata.schema
 
ExternalCompactionFinalState(ExternalCompactionId, KeyExtent, ExternalCompactionFinalState.FinalState, long, long) - Constructor for class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
ExternalCompactionFinalState.FinalState - Enum in org.apache.accumulo.core.metadata.schema
 
externalCompactionId - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
externalCompactionId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
ExternalCompactionId - Class in org.apache.accumulo.core.metadata.schema
 
ExternalCompactionMetadata - Class in org.apache.accumulo.core.metadata.schema
 
ExternalCompactionMetadata(Set<StoredTabletFile>, Set<StoredTabletFile>, TabletFile, String, CompactionKind, short, CompactionExecutorId, boolean, boolean, Long) - Constructor for class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
ExternalCompactionSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.ExternalCompactionSection
 
ExternalCompactionUtil - Class in org.apache.accumulo.core.util.compaction
 
ExternalCompactionUtil() - Constructor for class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
externalId(String) - Static method in class org.apache.accumulo.core.util.compaction.CompactionExecutorIdImpl
 

F

Factory() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
 
Factory() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.Factory
 
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.Factory
 
fail - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
FAIL - Enum constant in enum org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeExistsPolicy
 
FAIL - Enum constant in enum org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeMissingPolicy
 
FAIL - Enum constant in enum org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator.Behavior
 
FAIL - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
FAILED - Enum constant in enum org.apache.accumulo.core.compaction.thrift.TCompactionState
 
FAILED - Enum constant in enum org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Transaction has failed and has been fully rolled back
FAILED - Enum constant in enum org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState.FinalState
 
FAILED_EXTENTS - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
 
FAILED_IN_PROGRESS - Enum constant in enum org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Transaction has failed, and is in the process of being rolled back
failedExtents - Variable in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
failedToAcquireLock(Exception) - Method in interface org.apache.accumulo.core.fate.zookeeper.ServiceLock.AccumuloLockWatcher
 
fails() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.fails
 
fails() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.fails
 
fails() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
fails() - Method in interface org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Iface
 
fails(AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient
 
fails(AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncIface
 
fails_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
fails_args(ThriftTest.fails_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
Performs a deep copy on other.
fails_call(AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.fails_call
 
fails_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
fails_result(boolean) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
fails_result(ThriftTest.fails_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
Performs a deep copy on other.
failures - Variable in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
FAILURES - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
families(Collection<Column>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
Create a set of families to be passed into the SortedKeyValueIterator seek call from a supplied set of columns.
family(byte[]) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnFamilyStep
Set the column family of the Key that this builder will build to the parameter.
family(byte[]) - Method in interface org.apache.accumulo.core.data.Mutation.FamilyOptions
 
family(byte[], int, int) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnFamilyStep
Set the column family of the Key that this builder will build to the parameter.
family(CharSequence) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnFamilyStep
Set the column family of the Key that this builder will build to the parameter.
family(CharSequence) - Method in interface org.apache.accumulo.core.data.Mutation.FamilyOptions
 
family(ByteBuffer) - Method in interface org.apache.accumulo.core.data.Mutation.FamilyOptions
 
family(Text) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnFamilyStep
Set the column family of the Key that this builder will build to the parameter.
family(Text) - Method in interface org.apache.accumulo.core.data.Mutation.FamilyOptions
 
FamilySummarizer - Class in org.apache.accumulo.core.client.summary.summarizers
Counts column column families.
FamilySummarizer() - Constructor for class org.apache.accumulo.core.client.summary.summarizers.FamilySummarizer
 
FastFormat - Class in org.apache.accumulo.core.util
 
FastFormat() - Constructor for class org.apache.accumulo.core.util.FastFormat
 
fastHalt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
 
fastHalt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
 
fastHalt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
fastHalt(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
fastHalt(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
fastHalt(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
fastHalt_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
fastHalt_args(TabletClientService.fastHalt_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
Performs a deep copy on other.
fastHalt_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
fastHalt_call(TInfo, TCredentials, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.fastHalt_call
 
fastSkip(DataInput, Key, MutableByteSequence, Key, Key, int) - Static method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
Fate<T> - Class in org.apache.accumulo.core.fate
Fault tolerant executor
Fate(T, TStore<T>, Function<Repo<T>, String>) - Constructor for class org.apache.accumulo.core.fate.Fate
Creates a Fault-tolerant executor.
FATE - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
Fate.TxInfo - Enum in org.apache.accumulo.core.fate
 
FateLock - Class in org.apache.accumulo.core.fate.zookeeper
A persistent lock mechanism in ZooKeeper used for locking tables during FaTE operations.
FateLock(ZooReaderWriter, FateLock.FateLockPath) - Constructor for class org.apache.accumulo.core.fate.zookeeper.FateLock
 
FateLock.FateLockPath - Class in org.apache.accumulo.core.fate.zookeeper
 
FateLogger - Class in org.apache.accumulo.core.logging
 
FateLogger() - Constructor for class org.apache.accumulo.core.logging.FateLogger
 
FateOperation - Enum in org.apache.accumulo.core.manager.thrift
 
FateService - Class in org.apache.accumulo.core.manager.thrift
 
FateService() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService
 
FateService.AsyncClient - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncClient.beginFateOperation_call - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncClient.cancelFateOperation_call - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncClient.executeFateOperation_call - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncClient.Factory - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncClient.finishFateOperation_call - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncClient.waitForFateOperation_call - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncIface - Interface in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncProcessor<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncProcessor.beginFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncProcessor.cancelFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncProcessor.executeFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncProcessor.finishFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.AsyncProcessor.waitForFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.beginFateOperation_args - Class in org.apache.accumulo.core.manager.thrift
 
FateService.beginFateOperation_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.beginFateOperation_result - Class in org.apache.accumulo.core.manager.thrift
 
FateService.beginFateOperation_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.cancelFateOperation_args - Class in org.apache.accumulo.core.manager.thrift
 
FateService.cancelFateOperation_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.cancelFateOperation_result - Class in org.apache.accumulo.core.manager.thrift
 
FateService.cancelFateOperation_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.Client - Class in org.apache.accumulo.core.manager.thrift
 
FateService.Client.Factory - Class in org.apache.accumulo.core.manager.thrift
 
FateService.executeFateOperation_args - Class in org.apache.accumulo.core.manager.thrift
 
FateService.executeFateOperation_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.executeFateOperation_result - Class in org.apache.accumulo.core.manager.thrift
 
FateService.executeFateOperation_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.finishFateOperation_args - Class in org.apache.accumulo.core.manager.thrift
 
FateService.finishFateOperation_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.finishFateOperation_result - Class in org.apache.accumulo.core.manager.thrift
 
FateService.finishFateOperation_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.Iface - Interface in org.apache.accumulo.core.manager.thrift
 
FateService.Processor<I extends FateService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.Processor.beginFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.Processor.cancelFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.Processor.executeFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.Processor.finishFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.Processor.waitForFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
FateService.waitForFateOperation_args - Class in org.apache.accumulo.core.manager.thrift
 
FateService.waitForFateOperation_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateService.waitForFateOperation_result - Class in org.apache.accumulo.core.manager.thrift
 
FateService.waitForFateOperation_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FateThriftClient - Class in org.apache.accumulo.core.rpc.clients
 
FateTxId - Class in org.apache.accumulo.core.fate
 
FateTxId() - Constructor for class org.apache.accumulo.core.fate.FateTxId
 
fetch(ScannerBase) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
fetch(TabletMetadata.ColumnType...) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
fetch(TabletMetadata.ColumnType...) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.Options
 
fetchColumn(CharSequence, CharSequence) - Method in interface org.apache.accumulo.core.client.ScannerBase
Adds a column to the list of columns that will be fetched by this scanner.
fetchColumn(IteratorSetting.Column) - Method in interface org.apache.accumulo.core.client.ScannerBase
Adds a column to the list of columns that will be fetch by this scanner.
fetchColumn(IteratorSetting.Column) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
fetchColumn(Text, Text) - Method in interface org.apache.accumulo.core.client.ScannerBase
Adds a column to the list of columns that will be fetched by this scanner.
fetchColumn(Text, Text) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
fetchColumnFamily(CharSequence) - Method in interface org.apache.accumulo.core.client.ScannerBase
Adds a column family to the list of columns that will be fetched by this scanner.
fetchColumnFamily(Text) - Method in interface org.apache.accumulo.core.client.ScannerBase
Adds a column family to the list of columns that will be fetched by this scanner.
fetchColumnFamily(Text) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
fetchColumns(Class<?>, Configuration, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Restricts the columns that will be mapped over for the single input table on this job.
fetchColumns(Collection<Pair<Text, Text>>) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Deprecated.
Restricts the columns that will be mapped over for this job for the default input table.
fetchColumns(JobConf, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Deprecated.
Restricts the columns that will be mapped over for this job.
fetchColumns(Job, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Deprecated.
Restricts the columns that will be mapped over for this job for the default input table.
fetchedColumns - Variable in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
fieldForId(int) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
fieldForId(int) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
fieldForId(int) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
fieldForId(int) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
fieldForId(int) - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
fieldForId(int) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
fieldForId(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
fieldForId(int) - Method in exception org.apache.accumulo.core.manager.thrift.RecoveryException
 
fieldForId(int) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
fieldForId(int) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
fieldForId(int) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
fieldForId(int) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
fieldForId(int) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
fieldForId(int) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
fieldForId(int) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
fieldForId(int) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
fieldForId(int) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
fieldForId(int) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
FILE - Enum constant in enum org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase.TokenSource
 
FILE - Enum constant in enum org.apache.accumulo.core.data.LoadPlan.RangeType
Range that correspond to known rows in a file.
FILE_SIZE - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args._Fields
 
FILE_SIZE - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
 
FileDecrypter - Interface in org.apache.accumulo.core.spi.crypto
Class implementation that will decrypt a file.
FileEncrypter - Interface in org.apache.accumulo.core.spi.crypto
Class implementation that will encrypt a file.
FileHelper() - Constructor for class org.apache.accumulo.core.file.FileOperations.FileHelper
 
FileInfo(String, long, long) - Constructor for class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
FileInfo(Path, long) - Constructor for class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
fileLen(Cache<String, Long>) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
fileLenCache - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
filename - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
filename - Variable in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
filename - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
filename(String) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
FILENAME - Enum constant in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
 
FILENAME_EXT - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
filenames - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
FILENAMES - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
 
FileOperations - Class in org.apache.accumulo.core.file
 
FileOperations() - Constructor for class org.apache.accumulo.core.file.FileOperations
 
FileOperations.FileHelper - Class in org.apache.accumulo.core.file
Helper class extended by both writers and readers.
FileOperations.FileOptions - Class in org.apache.accumulo.core.file
 
FileOperations.IndexReaderBuilder - Class in org.apache.accumulo.core.file
Operation object for opening an index.
FileOperations.IndexReaderTableConfiguration - Interface in org.apache.accumulo.core.file
 
FileOperations.ReaderBuilder - Class in org.apache.accumulo.core.file
Options common to all FileOperations which perform reads.
FileOperations.ReaderTableConfiguration - Interface in org.apache.accumulo.core.file
 
FileOperations.ScanReaderBuilder - Class in org.apache.accumulo.core.file
Operation object for opening a scan reader.
FileOperations.ScanReaderTableConfiguration - Interface in org.apache.accumulo.core.file
 
FileOperations.WriterBuilder - Class in org.apache.accumulo.core.file
Operation object for constructing a writer.
FileOperations.WriterTableConfiguration - Interface in org.apache.accumulo.core.file
 
FileOptions(AccumuloConfiguration, String, FileSystem, Configuration, RateLimiter, String, FSDataOutputStream, boolean, CacheProvider, Cache<String, Long>, boolean, CryptoService, Range, Set<ByteSequence>, boolean, boolean) - Constructor for class org.apache.accumulo.core.file.FileOperations.FileOptions
 
FileOutputConfigurator - Class in org.apache.accumulo.core.clientImpl.mapreduce.lib
 
FileOutputConfigurator() - Constructor for class org.apache.accumulo.core.clientImpl.mapreduce.lib.FileOutputConfigurator
 
FileOutputConfigurator.Opts - Enum in org.apache.accumulo.core.clientImpl.mapreduce.lib
Configuration keys for AccumuloConfiguration.
FileParts(String, TableId, String, String, String) - Constructor for class org.apache.accumulo.core.metadata.TabletFile.FileParts
 
files - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
files - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
files - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
files - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
files - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
Files() - Constructor for class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
Files(Collection<Bulk.FileInfo>) - Constructor for class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
FILES - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args._Fields
 
FILES - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
FILES - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
 
FILES - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args._Fields
 
FILES - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args._Fields
 
FILES - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
FILES_CONTAINING - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
FILES_EXCEEDING - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
FILES_LARGE - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
filesContaining - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
filesExceeding - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
fileSize - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
fileSize - Variable in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
FileSKVIterator - Interface in org.apache.accumulo.core.file
 
FileSKVWriter - Interface in org.apache.accumulo.core.file
 
filesLarge - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
fileSystemForPath(String, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
filter(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
 
filter(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
Subclasses must provide an implementation which examines the given key and value and determines (1) whether to accept the KV pair and (2) how far to advance the source iterator past the key.
filter(Text, List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
filter(Text, List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
Filter - Class in org.apache.accumulo.core.bloomfilter
Defines the general behavior of a filter.
Filter - Class in org.apache.accumulo.core.iterators
A SortedKeyValueIterator that filters entries from its source iterator.
Filter() - Constructor for class org.apache.accumulo.core.bloomfilter.Filter
 
Filter() - Constructor for class org.apache.accumulo.core.iterators.Filter
 
Filter(int, int, int) - Constructor for class org.apache.accumulo.core.bloomfilter.Filter
Constructor.
FilteredConstants - Class in org.apache.accumulo.core
 
FilteredConstants() - Constructor for class org.apache.accumulo.core.FilteredConstants
 
filterInvalid(FileStatus[]) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
filterInvalidLabelsOnly(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
FilterResult(boolean, SeekingFilter.AdvanceResult) - Constructor for class org.apache.accumulo.core.iterators.user.SeekingFilter.FilterResult
 
FilterTransport - Class in org.apache.accumulo.core.rpc
Transport that simply wraps another transport.
FilterTransport(TTransport) - Constructor for class org.apache.accumulo.core.rpc.FilterTransport
 
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.bulkImportFiles_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_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.clientImpl.thrift.ClientService.getNamespaceProperties_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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getSystemProperties_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.clientImpl.thrift.ClientService.getSystemProperties_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.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_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.clientImpl.thrift.ClientService.getTableProperties_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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_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.clientImpl.thrift.ClientService.getVersionedSystemProperties_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.clientImpl.thrift.ClientService.getVersionedSystemProperties_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.clientImpl.thrift.ClientService.getVersionedTableProperties_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.clientImpl.thrift.ClientService.getVersionedTableProperties_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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.isActive_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.TDiskUsage._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ThriftTest.fails_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_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.compaction.thrift.CompactionCoordinatorService.cancel_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.compaction.thrift.CompactionCoordinatorService.compactionCompleted_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.compaction.thrift.CompactionCoordinatorService.compactionCompleted_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.compaction.thrift.CompactionCoordinatorService.compactionFailed_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.compaction.thrift.CompactionCoordinatorService.compactionFailed_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.compaction.thrift.CompactionCoordinatorService.getCompactionJob_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.compaction.thrift.CompactionCoordinatorService.getCompactionJob_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.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_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.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_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.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_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.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_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.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_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.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_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.compaction.thrift.CompactorService.cancel_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.compaction.thrift.CompactorService.cancel_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.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_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.compaction.thrift.CompactorService.getRunningCompaction_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.compaction.thrift.CompactorService.getRunningCompactionId_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.compaction.thrift.CompactorService.getRunningCompactionId_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.compaction.thrift.TCompactionStatusUpdate._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.TNextCompactionJob._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.thrift.TCMResult._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.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.dataImpl.thrift.TCondition._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.thrift.TRowRange._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.dataImpl.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.manager.thrift.DeadServer._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_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.manager.thrift.FateService.cancelFateOperation_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.manager.thrift.FateService.executeFateOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_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.manager.thrift.ManagerClientService.drainReplicationTable_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.manager.thrift.ManagerClientService.getActiveTservers_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.manager.thrift.ManagerClientService.getActiveTservers_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.manager.thrift.ManagerClientService.getDelegationToken_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.manager.thrift.ManagerClientService.getDelegationToken_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.manager.thrift.ManagerClientService.getManagerStats_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.manager.thrift.ManagerClientService.getManagerStats_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.manager.thrift.ManagerClientService.initiateFlush_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_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.manager.thrift.ManagerClientService.modifyNamespaceProperties_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.manager.thrift.ManagerClientService.modifySystemProperties_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.manager.thrift.ManagerClientService.modifySystemProperties_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.manager.thrift.ManagerClientService.modifyTableProperties_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.manager.thrift.ManagerClientService.modifyTableProperties_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.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.setManagerGoalState_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.manager.thrift.ManagerClientService.setManagerGoalState_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.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.waitForBalance_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.manager.thrift.ManagerClientService.waitForBalance_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.manager.thrift.ManagerClientService.waitForFlush_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.manager.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.manager.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.manager.thrift.ThriftPropertyException._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.BulkImportStatus._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.RecoveryStatus._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_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.replication.thrift.ReplicationCoordinator.getServicerAddress_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.replication.thrift.ReplicationCoordinatorException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_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.replication.thrift.ReplicationServicer.replicateKeyValues_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.replication.thrift.ReplicationServicer.replicateLog_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.replication.thrift.ReplicationServicer.replicateLog_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.replication.thrift.WalEdits._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_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.cancelUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_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.compactionJobFinished_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_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.contiuneGetSummaries_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_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.getActiveLogs_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.getCompactionQueueInfo_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.getCompactionQueueInfo_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_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.loadTablet_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_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.reserveCompactionJob_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.splitTablet_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_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.startGetSummaries_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.startGetSummariesForPartition_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.startGetSummariesForPartition_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.startGetSummariesFromFiles_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.startGetSummariesFromFiles_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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.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.TCompactionQueueSummary._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.TCompactionStats._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.TExternalCompactionJob._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._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.TSamplerConfiguration._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.bulkImportFiles_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_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.clientImpl.thrift.ClientService.getNamespaceProperties_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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getSystemProperties_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.clientImpl.thrift.ClientService.getSystemProperties_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.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_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.clientImpl.thrift.ClientService.getTableProperties_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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_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.clientImpl.thrift.ClientService.getVersionedSystemProperties_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.clientImpl.thrift.ClientService.getVersionedSystemProperties_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.clientImpl.thrift.ClientService.getVersionedTableProperties_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.clientImpl.thrift.ClientService.getVersionedTableProperties_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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.isActive_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.TDiskUsage._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ThriftTest.fails_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_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.compaction.thrift.CompactionCoordinatorService.cancel_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.compaction.thrift.CompactionCoordinatorService.compactionCompleted_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.compaction.thrift.CompactionCoordinatorService.compactionCompleted_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.compaction.thrift.CompactionCoordinatorService.compactionFailed_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.compaction.thrift.CompactionCoordinatorService.compactionFailed_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.compaction.thrift.CompactionCoordinatorService.getCompactionJob_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.compaction.thrift.CompactionCoordinatorService.getCompactionJob_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.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_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.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_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.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_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.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_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.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_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.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_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.compaction.thrift.CompactorService.cancel_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.compaction.thrift.CompactorService.cancel_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.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_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.compaction.thrift.CompactorService.getRunningCompaction_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.compaction.thrift.CompactorService.getRunningCompactionId_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.compaction.thrift.CompactorService.getRunningCompactionId_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.compaction.thrift.TCompactionStatusUpdate._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.TNextCompactionJob._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.thrift.TCMResult._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.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.dataImpl.thrift.TCondition._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.thrift.TRowRange._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.dataImpl.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.manager.thrift.DeadServer._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_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.manager.thrift.FateService.cancelFateOperation_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.manager.thrift.FateService.executeFateOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_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.manager.thrift.ManagerClientService.drainReplicationTable_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.manager.thrift.ManagerClientService.getActiveTservers_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.manager.thrift.ManagerClientService.getActiveTservers_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.manager.thrift.ManagerClientService.getDelegationToken_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.manager.thrift.ManagerClientService.getDelegationToken_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.manager.thrift.ManagerClientService.getManagerStats_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.manager.thrift.ManagerClientService.getManagerStats_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.manager.thrift.ManagerClientService.initiateFlush_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_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.manager.thrift.ManagerClientService.modifyNamespaceProperties_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.manager.thrift.ManagerClientService.modifySystemProperties_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.manager.thrift.ManagerClientService.modifySystemProperties_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.manager.thrift.ManagerClientService.modifyTableProperties_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.manager.thrift.ManagerClientService.modifyTableProperties_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.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.setManagerGoalState_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.manager.thrift.ManagerClientService.setManagerGoalState_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.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.waitForBalance_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.manager.thrift.ManagerClientService.waitForBalance_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.manager.thrift.ManagerClientService.waitForFlush_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.manager.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.manager.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.manager.thrift.ThriftPropertyException._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.BulkImportStatus._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.RecoveryStatus._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_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.replication.thrift.ReplicationCoordinator.getServicerAddress_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.replication.thrift.ReplicationCoordinatorException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_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.replication.thrift.ReplicationServicer.replicateKeyValues_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.replication.thrift.ReplicationServicer.replicateLog_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.replication.thrift.ReplicationServicer.replicateLog_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.replication.thrift.WalEdits._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_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.cancelUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_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.compactionJobFinished_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_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.contiuneGetSummaries_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_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.getActiveLogs_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.getCompactionQueueInfo_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.getCompactionQueueInfo_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_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.loadTablet_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_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.reserveCompactionJob_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.splitTablet_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_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.startGetSummaries_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.startGetSummariesForPartition_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.startGetSummariesForPartition_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.startGetSummariesFromFiles_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.startGetSummariesFromFiles_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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.TabletScanClientService.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.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.TCompactionQueueSummary._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.TCompactionStats._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.TExternalCompactionJob._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._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.TSamplerConfiguration._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.bulkImportFiles_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_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.clientImpl.thrift.ClientService.getNamespaceProperties_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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getSystemProperties_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.clientImpl.thrift.ClientService.getSystemProperties_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.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_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.clientImpl.thrift.ClientService.getTableProperties_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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_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.clientImpl.thrift.ClientService.getVersionedSystemProperties_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.clientImpl.thrift.ClientService.getVersionedSystemProperties_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.clientImpl.thrift.ClientService.getVersionedTableProperties_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.clientImpl.thrift.ClientService.getVersionedTableProperties_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.clientImpl.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.clientImpl.thrift.ClientService.getZooKeepers_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_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.compaction.thrift.CompactionCoordinatorService.cancel_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.compaction.thrift.CompactionCoordinatorService.compactionCompleted_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.compaction.thrift.CompactionCoordinatorService.compactionCompleted_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.compaction.thrift.CompactionCoordinatorService.compactionFailed_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.compaction.thrift.CompactionCoordinatorService.compactionFailed_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.compaction.thrift.CompactionCoordinatorService.getCompactionJob_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.compaction.thrift.CompactionCoordinatorService.getCompactionJob_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.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_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.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_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.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_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.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_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.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_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.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_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.compaction.thrift.CompactorService.cancel_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.compaction.thrift.CompactorService.cancel_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.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_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.compaction.thrift.CompactorService.getRunningCompaction_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.compaction.thrift.CompactorService.getRunningCompactionId_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.compaction.thrift.CompactorService.getRunningCompactionId_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.compaction.thrift.TCompactionStatusUpdate._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.TNextCompactionJob._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.MapFileInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyValue._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.DeadServer._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_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.manager.thrift.FateService.cancelFateOperation_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.manager.thrift.FateService.executeFateOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_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.manager.thrift.ManagerClientService.drainReplicationTable_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.manager.thrift.ManagerClientService.getActiveTservers_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.manager.thrift.ManagerClientService.getActiveTservers_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.manager.thrift.ManagerClientService.getDelegationToken_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.manager.thrift.ManagerClientService.getDelegationToken_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.manager.thrift.ManagerClientService.getManagerStats_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.manager.thrift.ManagerClientService.getManagerStats_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.manager.thrift.ManagerClientService.initiateFlush_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_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.manager.thrift.ManagerClientService.modifyNamespaceProperties_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.manager.thrift.ManagerClientService.modifySystemProperties_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.manager.thrift.ManagerClientService.modifySystemProperties_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.manager.thrift.ManagerClientService.modifyTableProperties_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.manager.thrift.ManagerClientService.modifyTableProperties_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.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_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.manager.thrift.ManagerClientService.setManagerGoalState_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.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_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.manager.thrift.ManagerClientService.waitForBalance_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.manager.thrift.ManagerClientService.waitForFlush_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.RecoveryException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_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.replication.thrift.ReplicationCoordinator.getServicerAddress_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.replication.thrift.ReplicationCoordinatorException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_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.replication.thrift.ReplicationServicer.replicateKeyValues_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.replication.thrift.ReplicationServicer.replicateLog_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.replication.thrift.ReplicationServicer.replicateLog_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.replication.thrift.WalEdits._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ConfigurationType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.compaction.thrift.TCompactionState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCMStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.manager.thrift.FateOperation
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerGoalState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.manager.thrift.TabletLoadState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.BulkImportState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorErrorCode
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionKind
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TDurability
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TUnloadTabletGoal
Find a the enum type by its integer value, as defined in the Thrift IDL.
findCompactionCoordinator(ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
findExportFile(ClientContext, Set<String>) - Static method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
Search multiple directories for exportMetadata.zip, the control file used for the importable command.
findLowestPrevPrefix(List<String>, String) - Static method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
Given a pre-sorted set of children ephemeral nodes where the node name is of the form "zlock#UUID#sequenceNumber", find the ephemeral node that sorts before the ephemeralNode parameter with the lowest sequence number
findMax(Scanner, Text, boolean, Text, boolean) - Static method in class org.apache.accumulo.core.client.admin.FindMax
 
FindMax - Class in org.apache.accumulo.core.client.admin
 
FindMax() - Constructor for class org.apache.accumulo.core.client.admin.FindMax
 
findOverlapping(KeyExtent, SortedMap<KeyExtent, ?>) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
findOverlapping(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
findOverlappingTablets(BulkImport.KeyExtentCache, FileSKVIterator) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
findOverlappingTablets(ClientContext, BulkImport.KeyExtentCache, Path, FileSystem, Cache<String, Long>, CryptoService) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
findTop() - Method in class org.apache.accumulo.core.iterators.Filter
Iterates over the source until an acceptable key/value pair is found.
findTop() - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
 
finish() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionOutputStream
 
finish() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
finished - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
finished - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
finished() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
finished() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
FINISHED - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
FINISHED - Enum constant in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
FINISHED - Enum constant in enum org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState.FinalState
 
finishFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.finishFateOperation
 
finishFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Processor.finishFateOperation
 
finishFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
finishFateOperation(TInfo, TCredentials, long) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.Iface
 
finishFateOperation(TInfo, TCredentials, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient
 
finishFateOperation(TInfo, TCredentials, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.AsyncIface
 
finishFateOperation_args() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
finishFateOperation_args(FateService.finishFateOperation_args) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
Performs a deep copy on other.
finishFateOperation_args(TInfo, TCredentials, long) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
finishFateOperation_call(TInfo, TCredentials, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.finishFateOperation_call
 
finishFateOperation_result() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
finishFateOperation_result(ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
finishFateOperation_result(FateService.finishFateOperation_result) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
Performs a deep copy on other.
FirstEntryInRowIterator - Class in org.apache.accumulo.core.iterators
 
FirstEntryInRowIterator() - Constructor for class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
FirstEntryInRowIterator(FirstEntryInRowIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
FIXED_LEN_ENCODER - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
FIXED_LONG_ARRAY_ENCODER - Static variable in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
FixedByteArrayOutputStream - Class in org.apache.accumulo.core.clientImpl.lexicoder
Uses a fixed length array and will not grow in size dynamically like the ByteArrayOutputStream.
FixedByteArrayOutputStream(byte[]) - Constructor for class org.apache.accumulo.core.clientImpl.lexicoder.FixedByteArrayOutputStream
 
FIXEDLEN - Enum constant in enum org.apache.accumulo.core.iterators.LongCombiner.Type
indicates a fixed-length (8-byte) encoding of a Long using LongCombiner.FixedLenEncoder
FIXEDLEN - Enum constant in enum org.apache.accumulo.core.iterators.user.SummingArrayCombiner.Type
indicates a fixed-length (8 bytes for each Long) encoding of a list of Longs using SummingArrayCombiner.FixedLongArrayEncoder
FixedLenEncoder() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
 
FixedLongArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.FixedLongArrayEncoder
 
fixedProperties - Static variable in enum org.apache.accumulo.core.conf.Property
 
flatten() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Generates a byte[] that represents a normalized, but logically equivalent, form of this evaluator's expression.
FloatLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for preserving the native Java sort order of Float values.
FloatLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.FloatLexicoder
 
flush() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
 
flush() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
 
flush() - Method in interface org.apache.accumulo.core.client.BatchWriter
Send any buffered mutations to Accumulo immediately.
flush() - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
Send mutations for all tables to accumulo.
flush() - Method in class org.apache.accumulo.core.clientImpl.BatchWriterImpl
 
flush() - Method in class org.apache.accumulo.core.clientImpl.MultiTableBatchWriterImpl
 
flush() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchWriter
 
flush() - Method in class org.apache.accumulo.core.crypto.streams.BlockedOutputStream
 
flush() - Method in class org.apache.accumulo.core.crypto.streams.NoFlushOutputStream
 
flush() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
 
flush() - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm.FinishOnFlushCompressionStream
 
flush() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
flush(boolean) - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
Forces a flush of data in memory to files before summary data is retrieved.
flush(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Initiate a flush of a table's data that is in memory.
flush(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
flush(String, Text, Text, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Flush a table's data that is currently in memory.
flush(String, Text, Text, boolean) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
FLUSH - Enum constant in enum org.apache.accumulo.core.client.Durability
Write mutations to the write-ahead log, and ensure the data is stored on remote servers, but perhaps not on persistent storage.
FLUSH - Enum constant in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
FLUSH - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TDurability
 
flush_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
flush_args(TabletClientService.flush_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
Performs a deep copy on other.
flush_args(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
flush_call(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flush_call
 
FLUSH_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
FLUSH_ID - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
FLUSH_ID - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
FLUSH_QUAL - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds flush IDs to enable waiting on a flush to complete
flushed(KeyExtent, Optional<StoredTabletFile>) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
flushID - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
flushs - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
FLUSHS - Enum constant in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
 
flushTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
 
flushTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
 
flushTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
flushTablet(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
flushTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
flushTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
flushTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
flushTablet_args(TabletClientService.flushTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
Performs a deep copy on other.
flushTablet_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
flushTablet_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flushTablet_call
 
followingKey(PartialKey) - Method in class org.apache.accumulo.core.data.Key
Returns a key that will sort immediately after this key.
followingPrefix(Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Text that sorts just after all Texts beginning with a prefix.
force - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
FORCE - Enum constant in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
 
forClient(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
forConfig(AccumuloConfiguration, boolean) - Static method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
forDirectory(TableId, String) - Static method in class org.apache.accumulo.core.gc.ReferenceFile
 
forEach(BiConsumer<? super Key, ? super Value>) - Method in interface org.apache.accumulo.core.client.ScannerBase
Iterates through Scanner results.
forFile(String, FileSystem, Configuration, CryptoService) - Method in class org.apache.accumulo.core.file.FileOperations.IndexReaderBuilder
 
forFile(String, FileSystem, Configuration, CryptoService) - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
 
forFile(String, FileSystem, Configuration, CryptoService) - Method in class org.apache.accumulo.core.file.FileOperations.ScanReaderBuilder
 
forFile(String, FileSystem, Configuration, CryptoService) - Method in class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
forFile(TableId, String) - Static method in class org.apache.accumulo.core.gc.ReferenceFile
 
forLevel(Ample.DataLevel) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
For a given data level, read all of its tablets metadata.
forLevel(Ample.DataLevel) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableOptions
Read all of the tablet metadata for this level.
format(Date, StringBuffer, FieldPosition) - Method in class org.apache.accumulo.core.util.format.FormatterConfig.DefaultDateFormat
 
formatEntry(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
formatEntry(Map.Entry<Key, Value>, boolean) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
formatEntry(Map.Entry<Key, Value>, boolean, int) - Static method in class org.apache.accumulo.core.util.format.BinaryFormatter
Deprecated.
 
formatEntry(Map.Entry<Key, Value>, DateFormat) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
Does not show timestamps if timestampFormat is null
formatEntry(Map.Entry<Key, Value>, FormatterConfig) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
Formatter - Interface in org.apache.accumulo.core.util.format
 
FormatterConfig - Class in org.apache.accumulo.core.util.format
Holds configuration settings for a Formatter
FormatterConfig() - Constructor for class org.apache.accumulo.core.util.format.FormatterConfig
 
FormatterConfig(FormatterConfig) - Constructor for class org.apache.accumulo.core.util.format.FormatterConfig
Copies most fields, but still points to other.dateFormatSupplier.
FormatterConfig.DefaultDateFormat - Class in org.apache.accumulo.core.util.format
Formats with milliseconds since epoch
FormatterFactory - Class in org.apache.accumulo.core.util.format
 
formatTid(long) - Static method in class org.apache.accumulo.core.fate.FateTxId
Formats transaction ids in a consistent way that is useful for logging and persisting.
forOutputStream(String, FSDataOutputStream, Configuration, CryptoService) - Method in class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
forScan(TableId, String) - Static method in class org.apache.accumulo.core.gc.ReferenceFile
 
forScanServer(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
forServer(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
forTable(TableId) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
For a given table read all of its tablet metadata.
forTable(TableId) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableOptions
This method automatically determines where the metadata for the passed in table ID resides.
forTableId(ClientContext, TableId) - Static method in class org.apache.accumulo.core.metadata.MetadataServicer
 
forTableName(ClientContext, String) - Static method in class org.apache.accumulo.core.metadata.MetadataServicer
 
forTablet(KeyExtent) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
forTablet(KeyExtent) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableOptions
Get the tablet metadata for this extents end row.
forTablets(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
forTablets(Collection<KeyExtent>) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableOptions
Get the tablet metadata for the given extents.
forTabletServer(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
FRACTION - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
from(String) - Method in interface org.apache.accumulo.core.client.AccumuloClient.PropertyOptions
Build using properties file.
from(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
from(String) - Static method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionId
Sanitize user input for the ECID string with proper "ECID:" prefix.
from(String) - Static method in class org.apache.accumulo.core.replication.ReplicationTarget
Deprecated.
Deserialize a ReplicationTarget
from(String...) - Method in interface org.apache.accumulo.core.client.rfile.RFile.InputArguments
Specify RFiles to read from.
from(String...) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryInputArguments
Specify RFiles to read from.
from(URL) - Method in interface org.apache.accumulo.core.client.AccumuloClient.PropertyOptions
Build using Java properties object.
from(URL) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
from(URL) - Static method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
from(Path) - Method in interface org.apache.accumulo.core.client.AccumuloClient.PropertyOptions
Build using properties file.
from(Path) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
from(Path) - Static method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
from(Properties) - Method in interface org.apache.accumulo.core.client.AccumuloClient.PropertyOptions
Build using Java properties object.
from(Properties) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
from(Properties) - Static method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
from(Properties, AuthenticationToken) - Static method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
from(AccumuloClient) - Static method in class org.apache.accumulo.core.client.Connector
Deprecated.
Creates a Connector from an AccumuloClient.
from(RFileSource...) - Method in interface org.apache.accumulo.core.client.rfile.RFile.InputArguments
Specify RFiles to read from.
from(RFileSource...) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryInputArguments
Specify RFiles to read from.
from(AccumuloConfiguration, AuthenticationToken) - Static method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
from(Text) - Static method in class org.apache.accumulo.core.replication.ReplicationTarget
Deprecated.
Deserialize a ReplicationTarget
fromBytes(byte[]) - Static method in class org.apache.accumulo.core.tabletserver.log.LogEntry
Deprecated, for removal: This API element is subject to removal in a future version.
fromEntry(Map.Entry<K1, V1>) - Static method in class org.apache.accumulo.core.util.Pair
 
fromEnv() - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
Build a SiteConfiguration from the environmental configuration with the option to override.
fromFile(File) - Static method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
Initializes a configuration object from the contents of a configuration file.
fromFile(File) - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
Build a SiteConfiguration from the provided properties file with the option to override.
fromJson(String) - Static method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
fromJson(ExternalCompactionId, String) - Static method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
fromMap(Map<String, String>) - Static method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
Initializes a configuration object from the contents of a map.
fromMetaPrevRow(Map.Entry<Key, Value>) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
Create a KeyExtent from a metadata previous end row entry.
fromMetaRow(Text) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
Create a KeyExtent from the table ID and the end row encoded in the row field of a tablet's metadata entry, with no previous end row.
fromMetaRow(Text, Text) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
Create a KeyExtent from the table ID and the end row encoded in the row field of a tablet's metadata entry, along with a previous end row.
fromMetaWalEntry(Map.Entry<Key, Value>) - Static method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
fromParts(String, int) - Static method in class org.apache.accumulo.core.util.HostAndPort
Build a HostAndPort instance from separate host and port values.
fromString(String) - Static method in class org.apache.accumulo.core.clientImpl.DurabilityImpl
 
fromString(String) - Static method in class org.apache.accumulo.core.fate.FateTxId
fromString(String) - Static method in class org.apache.accumulo.core.util.HostAndPort
Split a freeform string into a host and port, without strict validation.
fromStrings(String...) - Static method in class org.apache.accumulo.core.util.ByteArraySet
 
fromStrings(Collection<String>) - Static method in class org.apache.accumulo.core.util.ByteArraySet
 
fromTableProperties(Iterable<Map.Entry<String, String>>) - Static method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
 
fromTableProperties(Map<String, String>) - Static method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
Decodes table properties with the prefix table.summarizer into SummarizerConfiguration objects.
fromTabletId(TabletId) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
Create a KeyExtent from a TabletId.
fromThrift(SortedMap<TServerInstance, TabletServerStatus>, Map<KeyExtent, TServerInstance>, Map<KeyExtent, TServerInstance>) - Static method in class org.apache.accumulo.core.manager.balancer.AssignmentParamsImpl
 
fromThrift(SortedMap<TabletServerId, TServerStatus>, SortedMap<TServerInstance, TabletServerStatus>, Set<KeyExtent>) - Static method in class org.apache.accumulo.core.manager.balancer.BalanceParamsImpl
 
fromThrift(TKeyExtent) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
Create a KeyExtent from its Thrift form.
fromThrift(TSummarizerConfiguration) - Static method in class org.apache.accumulo.core.summary.SummarizerConfigurationUtil
 
fromThrift(TableInfo) - Static method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
fromThrift(TabletServerStatus) - Static method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
fromThrift(TServerInstance) - Static method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
fromThrift(TCredentials) - Static method in class org.apache.accumulo.core.clientImpl.Credentials
Converts a given thrift object to our internal Credentials representation.
fromThrift(TDurability) - Static method in class org.apache.accumulo.core.clientImpl.DurabilityImpl
 
fromThrift(TSamplerConfiguration) - Static method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
fromValue(Value) - Static method in class org.apache.accumulo.core.metadata.SuspendingTServer
 
fs - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
fs(FileSystem) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
fsConf - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
fsConf(Configuration) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
fsPath(FileSystem, Path) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
fsPath(FileSystem, Path, boolean) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
FULL - Enum constant in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
compaction that merges all of a tablets files into one file
FULL - Enum constant in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionType
 
FULL_SCANS - Enum constant in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
fullScans - Variable in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
future - Variable in class org.apache.accumulo.core.metadata.TabletLocationState
 
future(String, String) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
future(TServerInstance) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
FUTURE - Enum constant in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.LocationType
 
FutureLocationColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.FutureLocationColumnFamily
 
futureOrCurrent() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
futureOrCurrentServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 

G

gather(ExecutorService) - Method in class org.apache.accumulo.core.summary.Gatherer
 
Gatherer - Class in org.apache.accumulo.core.summary
This class implements using multiple tservers to gather summaries.
Gatherer(ClientContext, TSummaryRequest, AccumuloConfiguration, CryptoService) - Constructor for class org.apache.accumulo.core.summary.Gatherer
 
Gatherer.FileSystemResolver - Interface in org.apache.accumulo.core.summary
 
Gatherer.RowRange - Class in org.apache.accumulo.core.summary
 
GC - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
GC_CANDIDATE_BATCH_SIZE - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GC_CLIENT - Enum constant in enum org.apache.accumulo.core.util.ServerServices.Service
 
GC_CYCLE_DELAY - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GC_CYCLE_START - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GC_DELETE_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
GC_DELETE_THREADS - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GC_PORT - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GC_POST_ACTION - Enum constant in enum org.apache.accumulo.core.conf.PropertyType
 
GC_PREFIX - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GC_REMOVE_IN_USE_CANDIDATES - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GC_SAFEMODE - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GC_TRACE_PERCENT - Enum constant in enum org.apache.accumulo.core.conf.Property
Deprecated, for removal: This API element is subject to removal in a future version.
GC_TRASH_IGNORE - Enum constant in enum org.apache.accumulo.core.conf.Property
Deprecated, for removal: This API element is subject to removal in a future version.
GC_USE_FULL_COMPACTION - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GcCandidate - Class in org.apache.accumulo.core.gc
 
GcCandidate(String, long) - Constructor for class org.apache.accumulo.core.gc.GcCandidate
 
GcCycleStats - Class in org.apache.accumulo.core.gc.thrift
 
GcCycleStats() - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
GcCycleStats(long, long, long, long, long, long, long) - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
GcCycleStats(GcCycleStats) - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
Performs a deep copy on other.
GcCycleStats._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService
 
GCMonitorService.AsyncClient - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncClient.Factory - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncClient.getStatus_call - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncIface - Interface in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncProcessor<I extends GCMonitorService.AsyncIface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncProcessor.getStatus<I extends GCMonitorService.AsyncIface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Client - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Client.Factory - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.getStatus_args - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.getStatus_args._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService.getStatus_result - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.getStatus_result._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService.Iface - Interface in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Processor<I extends GCMonitorService.Iface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Processor.getStatus<I extends GCMonitorService.Iface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorServiceThriftClient - Class in org.apache.accumulo.core.rpc.clients
 
GCStatus - Class in org.apache.accumulo.core.gc.thrift
 
GCStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
 
GCStatus(GcCycleStats, GcCycleStats, GcCycleStats, GcCycleStats) - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
 
GCStatus(GCStatus) - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
Performs a deep copy on other.
GCStatus._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GENERAL_ARBITRARY_PROP_PREFIX - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_CLASSPATHS - Enum constant in enum org.apache.accumulo.core.conf.Property
Deprecated.
GENERAL_CONTEXT_CLASSLOADER_FACTORY - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_DELEGATION_TOKEN_LIFETIME - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_DELEGATION_TOKEN_UPDATE_INTERVAL - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_DYNAMIC_CLASSPATHS - Enum constant in enum org.apache.accumulo.core.conf.Property
Deprecated.
GENERAL_FILE_NAME_ALLOCATION_BATCH_SIZE_MAX - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_FILE_NAME_ALLOCATION_BATCH_SIZE_MIN - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_IDLE_PROCESS_INTERVAL - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_KERBEROS_KEYTAB - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_KERBEROS_PRINCIPAL - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_KERBEROS_RENEWAL_PERIOD - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_MAX_MESSAGE_SIZE - Enum constant in enum org.apache.accumulo.core.conf.Property
Deprecated.
GENERAL_MAX_SCANNER_RETRY_PERIOD - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_MICROMETER_ENABLED - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_MICROMETER_FACTORY - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_MICROMETER_JVM_METRICS_ENABLED - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_OPENTELEMETRY_ENABLED - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_PREFIX - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_RPC_SERVER_TYPE - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_RPC_TIMEOUT - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS - Enum constant in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
Deprecated.
 
GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_SERVER_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
GENERAL_SERVER_SIMPLETIMER_POOL - Enum constant in enum org.apache.accumulo.core.util.threads.ThreadPoolNames
 
GENERAL_SERVICE_NAME_PROP - Static variable in class org.apache.accumulo.core.spi.crypto.GenericCryptoServiceFactory
 
GENERAL_SIMPLETIMER_THREADPOOL_SIZE - Enum constant in enum org.apache.accumulo.core.conf.Property
Deprecated.
GENERAL_THREADPOOL_SIZE - Enum constant in enum org.apache.accumulo.core.conf.Property
 
GENERAL_VOLUME_CHOOSER - Enum constant in enum org.apache.accumulo.core.conf.Property
 
generate(UUID) - Static method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionId
 
GENERATED_TABLET_DIRECTORY_PREFIX - Static variable in class org.apache.accumulo.core.Constants
 
generateInitialTableProperties(boolean) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
Generate the initial (default) properties for a table
generateKey(SecureRandom, int) - Static method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
GenerateSplits - Class in org.apache.accumulo.core.file.rfile
 
GenerateSplits() - Constructor for class org.apache.accumulo.core.file.rfile.GenerateSplits
 
GenericCryptoServiceFactory - Class in org.apache.accumulo.core.spi.crypto
Factory that will load a crypto service configured, first checking GenericCryptoServiceFactory.GENERAL_SERVICE_NAME_PROP and then GenericCryptoServiceFactory.TABLE_SERVICE_NAME_PROP.
GenericCryptoServiceFactory() - Constructor for class org.apache.accumulo.core.spi.crypto.GenericCryptoServiceFactory
 
get() - Method in class org.apache.accumulo.core.data.Value
Gets the byte data of this value.
get() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlockQueue
Get a sorted List of all elements in this queue, in descending order.
get() - Method in class org.apache.accumulo.core.util.CancelFlagFuture
 
get() - Method in class org.apache.accumulo.core.util.format.DateFormatSupplier
Always sets the TimeZone, which is a fast operation
get(int) - Method in class org.apache.accumulo.core.util.PreAllocatedArray
Get the item stored at the specified index.
get(long, TimeUnit) - Method in class org.apache.accumulo.core.util.CancelFlagFuture
 
get(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
get(String) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
 
get(String) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
get(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property value from this configuration.
get(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Gets data at the given path.
get(String) - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
 
get(String) - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
 
get(String) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
get(String, ZooCache.ZcStat) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Gets data at the given path, filling status information into the given Stat object.
get(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
get(KT) - Method in class org.apache.accumulo.core.util.MapCounter
 
get(ClientConfiguration.ClientProperty) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
Returns the value for prop, the default value if not present.
get(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property value from this configuration.
get(Property) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
get(Property) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
get(Property) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
get(Path) - Method in interface org.apache.accumulo.core.summary.Gatherer.FileSystemResolver
 
GET_SUMMARIES - Enum constant in enum org.apache.accumulo.core.security.TablePermission
 
getAcceptableFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getAccumuloClient() - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
getAccumuloConfiguration(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.FileOutputConfigurator
This helper method provides an AccumuloConfiguration object constructed from the Accumulo defaults, and overridden with Accumulo properties that have been stored in the Job's configuration.
getACL(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Retrieve the ACL list that was on the node
getActiveCompaction(HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
getActiveCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getActiveCompactions
 
getActiveCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getActiveCompactions
 
getActiveCompactions() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
 
getActiveCompactions() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
 
getActiveCompactions() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List all internal and external compactions running in Accumulo.
getActiveCompactions() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getActiveCompactions(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the active compaction running on a tablet server.
getActiveCompactions(String) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
getActiveCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.Iface
 
getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getActiveCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncIface
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getActiveCompactions_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getActiveCompactions_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
getActiveCompactions_args(CompactorService.getActiveCompactions_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
Performs a deep copy on other.
getActiveCompactions_args(TabletClientService.getActiveCompactions_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
Performs a deep copy on other.
getActiveCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getActiveCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
getActiveCompactions_call(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getActiveCompactions_call
 
getActiveCompactions_call(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveCompactions_call
 
getActiveCompactions_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getActiveCompactions_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getActiveCompactions_result(List<ActiveCompaction>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getActiveCompactions_result(List<ActiveCompaction>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getActiveCompactions_result(CompactorService.getActiveCompactions_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
Performs a deep copy on other.
getActiveCompactions_result(TabletClientService.getActiveCompactions_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
Performs a deep copy on other.
getActiveLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveLogs
 
getActiveLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveLogs
 
getActiveLogs(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getActiveLogs(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getActiveLogs(TInfo, TCredentials, AsyncMethodCallback<List<String>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getActiveLogs(TInfo, TCredentials, AsyncMethodCallback<List<String>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getActiveLogs_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
getActiveLogs_args(TabletClientService.getActiveLogs_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
Performs a deep copy on other.
getActiveLogs_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
getActiveLogs_call(TInfo, TCredentials, AsyncMethodCallback<List<String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveLogs_call
 
getActiveLogs_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
getActiveLogs_result(List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
getActiveLogs_result(TabletClientService.getActiveLogs_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
Performs a deep copy on other.
getActiveScans() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.getActiveScans
 
getActiveScans() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.getActiveScans
 
getActiveScans(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the active scans on a tablet server.
getActiveScans(String) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getActiveScans(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client
 
getActiveScans(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Iface
 
getActiveScans(TInfo, TCredentials, AsyncMethodCallback<List<ActiveScan>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient
 
getActiveScans(TInfo, TCredentials, AsyncMethodCallback<List<ActiveScan>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncIface
 
getActiveScans_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
getActiveScans_args(TabletScanClientService.getActiveScans_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
Performs a deep copy on other.
getActiveScans_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
getActiveScans_call(TInfo, TCredentials, AsyncMethodCallback<List<ActiveScan>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.getActiveScans_call
 
getActiveScans_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
getActiveScans_result(List<ActiveScan>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
getActiveScans_result(TabletScanClientService.getActiveScans_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
Performs a deep copy on other.
getActiveTservers() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getActiveTservers
 
getActiveTservers() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getActiveTservers
 
getActiveTservers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
getActiveTservers(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
getActiveTservers(TInfo, TCredentials, AsyncMethodCallback<List<String>>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
getActiveTservers(TInfo, TCredentials, AsyncMethodCallback<List<String>>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
getActiveTservers_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getActiveTservers_args(ManagerClientService.getActiveTservers_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
Performs a deep copy on other.
getActiveTservers_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getActiveTservers_call(TInfo, TCredentials, AsyncMethodCallback<List<String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getActiveTservers_call
 
getActiveTservers_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getActiveTservers_result(List<String>, ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getActiveTservers_result(ManagerClientService.getActiveTservers_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
Performs a deep copy on other.
getAddress() - Method in interface org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost
 
getAddress() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerInfo
 
getAddress(ServerServices.Service) - Method in class org.apache.accumulo.core.util.ServerServices
 
getAddressCacheNegativeTtl(UnknownHostException) - Static method in class org.apache.accumulo.core.util.AddressUtil
Fetch the security value that determines how long DNS failures are cached.
getAddressString(ServerServices.Service) - Method in class org.apache.accumulo.core.util.ServerServices
 
getAge() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getAge() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getAge() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getAge() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAll() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getAllCryptoProperties() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getAllPropertiesWithPrefix(ClientConfiguration.ClientProperty) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
Gets all properties under the given prefix in this configuration.
getAllPropertiesWithPrefix(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets all properties under the given prefix in this configuration.
getAllPropertiesWithPrefixStripped(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getAmple() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getAnonymousSession(String, int) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooSession
 
getAnyCachedTransport(ThriftClientTypes<?>) - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportPool
 
getArguments() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getArgumentsIterator() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getArgumentsSize() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getAsBytes(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.BYTES or PropertyType.MEMORY, interpreting the value properly.
getAssignment(SortedMap<TabletServerId, TServerStatus>, TabletServerId) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer
Assign tablets to tablet servers.
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.Factory
 
getAttempts(TabletId) - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.SelectorParameters
 
getAuthenticatedSession(String, int, String, byte[]) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooSession
 
getAuthenticationToken() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getAuthenticationToken() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getAuthenticationToken() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getAuthenticationToken(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken(Properties) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
getAuthenticationToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthenticationToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
getAuthorizationFailures() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getAuthorizationFailuresSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getAuthorizations() - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the authorizations that have been set on the scanner
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReader
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizations() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Return the Scan Authorizations used in this Iterator.
getAuthorizations() - Method in class org.apache.accumulo.core.security.Authorizations
Gets the authorizations in sorted order.
getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getAuthorizationsArray() - Method in class org.apache.accumulo.core.security.Authorizations
Returns a serialized form of these authorizations.
getAuthorizationsBB() - Method in class org.apache.accumulo.core.security.Authorizations
Gets the authorizations in sorted order.
getAuthorizationsContainer() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
Deprecated.
Gets the authorizations in the environment.
getAuthorizationsContainer() - Method in interface org.apache.accumulo.core.data.constraints.Constraint.Environment
Gets the authorizations in the environment.
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getAuths() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getAutoAdjustRanges(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Determines whether a configuration has auto-adjust ranges enabled.
getAutoAdjustRanges(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Deprecated.
Determines whether a configuration has auto-adjust ranges enabled.
getAutoAdjustRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Deprecated.
Determines whether a configuration has auto-adjust ranges enabled.
getAvailableFiles() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getBackingArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
getBackingArray() - Method in class org.apache.accumulo.core.data.ByteSequence
Gets the backing byte array for this sequence.
getBadTServers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBadTServersSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBalancerForTable(TableId) - Method in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
getBasePath() - Method in interface org.apache.accumulo.core.volume.Volume
The base path which Accumulo will use within the given FileSystem
getBasePath() - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
getBatch() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getBatchFromServer(ClientContext, Range, KeyExtent, String, SortedMap<Key, Value>, SortedSet<Column>, List<IterInfo>, Map<String, Map<String, String>>, int, Authorizations, long, String) - Static method in class org.apache.accumulo.core.clientImpl.ThriftScanner
 
getBatchScanner(AccumuloClient, int) - Static method in class org.apache.accumulo.core.replication.ReplicationTable
Deprecated.
 
getBatchSize() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getBatchSize() - Method in interface org.apache.accumulo.core.client.Scanner
Returns the batch size (number of Key/Value pairs) that will be fetched at a time from a tablet server.
getBatchSize() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getBatchTimeout(TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the timeout to fill a batch in the given TimeUnit.
getBatchTimeout(TimeUnit) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getBatchTimeOut() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getBatchTimeOut() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getBatchWriter(String) - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
Returns a BatchWriter for a particular table.
getBatchWriter(String) - Method in class org.apache.accumulo.core.clientImpl.MultiTableBatchWriterImpl
 
getBatchWriter(AccumuloClient) - Static method in class org.apache.accumulo.core.replication.ReplicationTable
Deprecated.
 
getBatchWriterConfig() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getBatchWriterOptions(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.OutputConfigurator
Gets the BatchWriterConfig settings.
getBatchWriterOptions(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
Gets the BatchWriterConfig settings.
getBatchWriterOptions(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
Gets the BatchWriterConfig settings.
getBehavior(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator
 
getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the buffer of the block with the specified name.
getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getBlock(String) - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Fetch block from cache.
getBlock(String, BlockCache.Loader) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.SynchronousLoadingBlockCache
 
getBlock(String, BlockCache.Loader) - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getBlock(String, BlockCache.Loader) - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getBlock(String, BlockCache.Loader) - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
This method allows a cache to prevent concurrent loads of the same block.
getBlockCache(CacheType) - Method in class org.apache.accumulo.core.spi.cache.BlockCacheManager
Get the block cache of the given type
getBlockCount() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Get the number of data blocks.
getBlockNoStats(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getBlockNoStats(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.SynchronousLoadingBlockCache
Get a block from the cache without changing any stats the cache is keeping.
getBlockSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getBlockSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getBlockSize() - Method in interface org.apache.accumulo.core.spi.cache.BlockCacheManager.Configuration
Before Accumulo's cache implementation was configurable, its built in cache had a configurable block size.
getBoolean(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getBoolean(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.BOOLEAN, interpreting the value properly (using Boolean.parseBoolean()).
getBounds() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getBuffer() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getBuffer() - Method in interface org.apache.accumulo.core.spi.cache.CacheEntry
 
getBufferPosition() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getBufferSizeProperty() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getBulkImports() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBulkImports() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getBulkImportsIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBulkImportsIterator() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getBulkImportsSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBulkImportsSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getBulkLoadTid(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
getBulkLoadTid(Value) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
getBulks() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getBulkWorkingFiles() - Static method in class org.apache.accumulo.core.file.FileOperations
 
getBusyTimeout() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelections
 
getBusyTimeout() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
getBusyTimeout() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
getBusyTimeout() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getBusyTimeout() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getByteBuffer(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
getBytes() - Method in class org.apache.accumulo.core.dataImpl.ComparableBytes
Gets the wrapped bytes in this object.
getBytes(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getBytes(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
getBytesRead() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
getBytesRead() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
getBytesRemainingInBuffer() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getBytesWritten() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
getBytesWritten() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
getCachePropertyBase(Property) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getCacheProvider() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getCacheType() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getCallbackHandler() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The SASL callback handler for this mechanism, may be null.
getCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getCandidates() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getCf() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getCfg() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getChildren() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getChildren(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Gets the children of the given node.
getChildren(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getChildren(String, Watcher) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getChooserScope() - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment
 
getClassInstance(String, String, Class<T>) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Loads a class in the given classloader context.
getClassInstance(String, String, Class<T>, T) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Loads a class in the given classloader context, suppressing any exceptions, and optionally providing a default instance to use.
getClassLoader(String) - Static method in class org.apache.accumulo.core.classloader.ClassLoaderUtil
 
getClassLoader(String) - Method in class org.apache.accumulo.core.classloader.DefaultContextClassLoaderFactory
 
getClassLoader(String) - Method in interface org.apache.accumulo.core.spi.common.ContextClassLoaderFactory
Get the class loader for the given contextName.
getClassLoaderContext() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Returns the name of the current classloader context set on this scanner
getClassLoaderContext() - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the name of the current classloader context set on this scanner
getClassLoaderContext() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getClassLoaderContext(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Gets the name of the context classloader to use for scans
getClassLoaderContext(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Returns the name of the current classloader context set on this scanner
getClassLoaderContext(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Returns the name of the current classloader context set on this scanner
getClassname() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getClassName() - Method in class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
Deprecated.
 
getClassName() - Method in class org.apache.accumulo.core.client.admin.PluginConfig
 
getClassName() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
 
getClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getClassName() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
getClassName() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
getClassName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
getClient() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getClient() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getClient() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getClient(ThriftClientTypes<T>, HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a Thrift client using the given factory with a pooled transport (if available), the address and client context.
getClient(ThriftClientTypes<T>, HostAndPort, ClientContext, long) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a Thrift client using the given factory with a pooled transport (if available) using the address, client context and timeout
getClient(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Client.Factory
 
getClientConfigFile() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getClientConfiguration(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
Obtain a ClientConfiguration based on the configuration.
getClientConfiguration(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Fetch the client configuration from the job.
getClientConfiguration(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Construct the ClientConfiguration given the provided context.
getClientContext() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getClientFactory() - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getClientInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheManagerFactory
Get the BlockCacheFactory specified by the property 'tserver.cache.factory.class'
getClientNoTimeout(ThriftClientTypes<T>, HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a Thrift client using the given factory with a pooled transport (if available), the address, and client context with no timeout.
getClientProps() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getClientProtocol() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getClientReservation() - Static method in class org.apache.accumulo.core.singletons.SingletonManager
This method should be called when creating Accumulo clients using the public API.
getClientScanIterators() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
 
getClientSslParams() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve SSL/TLS configuration to initiate an RPC connection to a server
getClientString() - Method in class org.apache.accumulo.core.rpc.TBufferedSocket
 
getClientThreadPools(Thread.UncaughtExceptionHandler) - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
 
getClientTimeoutInMillis() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve the universal RPC client timeout from the configuration
getCloned() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getCmid() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
getCode() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
getCode() - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
getCode() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
getCode() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
getCode(String) - Static method in class org.apache.accumulo.core.metadata.schema.SortSkew
Creates a left justified hex string for the path hashcode of a deterministic length, therefore if necessary it is right padded with zeros
getCode(TimeType) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getCodecClassName() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getCodecClassNameProperty() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getColFamily() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getColQualifier() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getColumnFamilies() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getColumnFamily() - Method in class org.apache.accumulo.core.client.IteratorSetting.Column
 
getColumnFamily() - Method in class org.apache.accumulo.core.data.Column
Gets the column family.
getColumnFamily() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Gets the column family for this update.
getColumnFamily() - Method in class org.apache.accumulo.core.data.Key
Gets the column family as a Text object.
getColumnFamily() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
getColumnFamily() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getColumnFamily() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
getColumnFamily(Text) - Method in class org.apache.accumulo.core.data.Key
Writes the column family into the given Text.
getColumnFamilyData() - Method in class org.apache.accumulo.core.data.Key
Returns the column family as a byte sequence.
getColumnQualifier() - Method in class org.apache.accumulo.core.client.IteratorSetting.Column
 
getColumnQualifier() - Method in class org.apache.accumulo.core.data.Column
Gets the column qualifier.
getColumnQualifier() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Gets the column qualifier for this update.
getColumnQualifier() - Method in class org.apache.accumulo.core.data.Key
Gets the column qualifier as a Text object.
getColumnQualifier() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
getColumnQualifier() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getColumnQualifier() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
getColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
Writes the column qualifier into the given Text.
getColumnQualifierData() - Method in class org.apache.accumulo.core.data.Key
Returns the column qualifier as a byte sequence.
getColumns() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getColumns() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getColumnVisibility() - Method in class org.apache.accumulo.core.data.Column
Gets the column visibility.
getColumnVisibility() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Gets the column visibility for this update.
getColumnVisibility() - Method in class org.apache.accumulo.core.data.Key
Gets the column visibility as a Text object.
getColumnVisibility() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
getColumnVisibility(Text) - Method in class org.apache.accumulo.core.data.Key
Writes the column visibility into the given Text.
getColumnVisibilityData() - Method in class org.apache.accumulo.core.data.Key
Returns the column visibility as a byte sequence.
getColumnVisibilityParsed() - Method in class org.apache.accumulo.core.data.Key
Gets the column visibility.
getColVisibility() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getCommonTags() - Method in interface org.apache.accumulo.core.metrics.MetricsInfo
Get the current list of common tags.
getCompactId() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getCompactionAgeNanos() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getCompactionExecutorId() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getCompactionId() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getCompactionIdsRunningOnCompactors(ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
getCompactionJob() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompactionJob
 
getCompactionJob() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompactionJob
 
getCompactionJob(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
getCompactionJob(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
getCompactionJob(TInfo, TCredentials, String, String, String, AsyncMethodCallback<TNextCompactionJob>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
getCompactionJob(TInfo, TCredentials, String, String, String, AsyncMethodCallback<TNextCompactionJob>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
getCompactionJob_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getCompactionJob_args(CompactionCoordinatorService.getCompactionJob_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
Performs a deep copy on other.
getCompactionJob_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getCompactionJob_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback<TNextCompactionJob>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompactionJob_call
 
getCompactionJob_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
getCompactionJob_result(CompactionCoordinatorService.getCompactionJob_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
Performs a deep copy on other.
getCompactionJob_result(TNextCompactionJob) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
getCompactionKind() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.DispatchParameters
 
getCompactionQueueInfo() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getCompactionQueueInfo
 
getCompactionQueueInfo() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getCompactionQueueInfo
 
getCompactionQueueInfo(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getCompactionQueueInfo(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getCompactionQueueInfo(TInfo, TCredentials, AsyncMethodCallback<List<TCompactionQueueSummary>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getCompactionQueueInfo(TInfo, TCredentials, AsyncMethodCallback<List<TCompactionQueueSummary>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getCompactionQueueInfo_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
getCompactionQueueInfo_args(TabletClientService.getCompactionQueueInfo_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
Performs a deep copy on other.
getCompactionQueueInfo_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
getCompactionQueueInfo_call(TInfo, TCredentials, AsyncMethodCallback<List<TCompactionQueueSummary>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getCompactionQueueInfo_call
 
getCompactionQueueInfo_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
getCompactionQueueInfo_result(List<TCompactionQueueSummary>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
getCompactionQueueInfo_result(TabletClientService.getCompactionQueueInfo_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
Performs a deep copy on other.
getCompactions() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
getCompactionServices() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.DispatchParameters
 
getCompactionsRunningOnCompactors(ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
This method returns information from the Compactor about the job that is currently running.
getCompactionsSize() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
getCompactionStrategy() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
Deprecated, for removal: This API element is subject to removal in a future version.
since 2.1.0
getCompactor() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getCompactor() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getCompactor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
getCompactorAddress() - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
getCompactorAddrs(ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
getCompactorCount() - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
getCompactorId() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getCompactTmpName() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getCompletedCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions
 
getCompletedCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompletedCompactions
 
getCompletedCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
getCompletedCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
getCompletedCompactions(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
getCompletedCompactions(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
getCompletedCompactions_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getCompletedCompactions_args(CompactionCoordinatorService.getCompletedCompactions_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
Performs a deep copy on other.
getCompletedCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getCompletedCompactions_call(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompletedCompactions_call
 
getCompletedCompactions_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
getCompletedCompactions_result(CompactionCoordinatorService.getCompletedCompactions_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
Performs a deep copy on other.
getCompletedCompactions_result(TExternalCompactionList) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
Get the compressed size of the block in progress.
getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getCompression() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getCompressionAlgorithmByName(String) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Compression
 
getCompressor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
getCompressorType() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
getConditionalWriterConfig() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getConditions() - Method in class org.apache.accumulo.core.data.ConditionalMutation
 
getConditions() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getConditionsIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getConditionsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getConf() - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
Deprecated.
 
getConf() - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
Deprecated.
 
getConfig() - Method in class org.apache.accumulo.core.clientImpl.ConditionalWriterImpl
 
getConfig() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getConfig() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Deprecated.
since 2.0.0. This method was using an unstable non public type. Use IteratorEnvironment.getPluginEnv()
getConfig() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor
 
getConfigId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getConfiguration
 
getConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getConfiguration
 
getConfiguration() - Method in interface org.apache.accumulo.core.client.PluginEnvironment
 
getConfiguration() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve the configuration used to construct this context
getConfiguration() - Method in class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
getConfiguration() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getConfiguration() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getConfiguration() - Method in interface org.apache.accumulo.core.spi.common.ContextClassLoaderEnvironment
Get the service environment configuration
getConfiguration() - Method in interface org.apache.accumulo.core.spi.common.ServiceEnvironment
 
getConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Gets a merged view of the properties of a namespace with its parent configuration.
getConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets a merged view of the properties of a table with its parent configuration.
getConfiguration(String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
getConfiguration(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getConfiguration(TableId) - Method in interface org.apache.accumulo.core.client.PluginEnvironment
 
getConfiguration(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
getConfiguration(TableId) - Method in interface org.apache.accumulo.core.spi.common.ServiceEnvironment
 
getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getConfiguration(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getConfiguration(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getConfiguration_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getConfiguration_args(ClientService.getConfiguration_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
Performs a deep copy on other.
getConfiguration_args(TInfo, TCredentials, ConfigurationType) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getConfiguration_call(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getConfiguration_call
 
getConfiguration_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getConfiguration_result(Map<String, String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getConfiguration_result(ClientService.getConfiguration_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
Performs a deep copy on other.
getConfigurer() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getConnection(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.FateThriftClient
 
getConnection(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.ManagerThriftClient
 
getConnection(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.ReplicationCoordinatorThriftClient
 
getConnection(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getConnectionWithRetry(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.ReplicationCoordinatorThriftClient
 
getConnectionWithRetry(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getConnector(String, byte[]) - Method in interface org.apache.accumulo.core.client.Instance
getConnector(String, CharSequence) - Method in interface org.apache.accumulo.core.client.Instance
getConnector(String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.Instance
getConnector(String, AuthenticationToken) - Method in interface org.apache.accumulo.core.client.Instance
Deprecated.
Returns a connection to this instance of accumulo.
getConnector(String, AuthenticationToken) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
 
getConsistencyLevel() - Method in interface org.apache.accumulo.core.client.ScannerBase
Get the configured consistency level
getConsistencyLevel() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getConstrainClass() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getConstrainClass() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
getConstraintViolationSummaries() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getCount() - Method in class org.apache.accumulo.core.iteratorsImpl.system.CountingIterator
 
getCount() - Method in class org.apache.accumulo.core.spi.crypto.PerTableCryptoServiceFactory
 
getCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getCount(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.COUNT, interpreting the value properly (as an integer).
getCounters() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getCq() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getCreationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getCreationTime() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
Returns the first time a tablet knew about a scan over its portion of data.
getCredentialProviders() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve the credentials used to construct this context
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getCredentials() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
getCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
getCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getCryptoEnv(CryptoEnvironment.Scope, TableId, DataInputStream) - Static method in class org.apache.accumulo.core.crypto.CryptoUtils
 
getCryptoService() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getCryptoService() - Method in class org.apache.accumulo.core.file.rfile.bcfile.PrintBCInfo
 
getCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getCurrentKey() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
getCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getCurrentMaxThreads() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
Re-reads the max threads from the configuration that created this class
getCurrentServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getCurrentSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the current size of this cache.
getCurrentValue() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
getCustom() - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Users can set arbitrary custom properties in Accumulo using the prefix general.custom..
getCustom() - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getCustom(String) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
This method appends the prefix general.custom and gets the property.
getCustom(String) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getCv() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getCve() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getDanglingHeldLocks() - Method in class org.apache.accumulo.core.fate.AdminUtil.FateStatus
Get locks that are held by non existent FATE transactions.
getDanglingWaitingLocks() - Method in class org.apache.accumulo.core.fate.AdminUtil.FateStatus
Get locks that are waiting to be acquired by non existent FATE transactions.
getData() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getData() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
getData() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
getData(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getData(String, Stat) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getData(String, Watcher) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getData(String, Watcher, Stat) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getDataBlock(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
It is intended that once the BlockRead object is returned to the caller, that the caller will read the entire block and then call close on the BlockRead class.
getDataBlock(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Stream access to a Data Block.
getDataBlock(long, long, long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
getDataBlock(long, long, long) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
getDataBlockRawSize(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
getDataCache() - Method in class org.apache.accumulo.core.file.blockfile.impl.BasicCacheProvider
 
getDataCache() - Method in interface org.apache.accumulo.core.file.blockfile.impl.CacheProvider
 
getDataCache() - Method in class org.apache.accumulo.core.file.blockfile.impl.ScanCacheProvider
 
getDataCacheHits() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getDataCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getDataCacheHits() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getDataCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getDataCacheRequests() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getDataCacheRequests() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getDataCacheUsage() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch
 
getDateFormatSupplier() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
 
getDeadTabletServers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getDeadTabletServersIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getDeadTabletServersSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getDecompressor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
getDecompressorType() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
getDecrypter(Key) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule
 
getDecrypter(Key) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule
 
getDecryptionParameters() - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule.AESCBCFileEncrypter
 
getDecryptionParameters() - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule.AESGCMFileEncrypter
 
getDecryptionParameters() - Method in interface org.apache.accumulo.core.spi.crypto.FileEncrypter
Get all the parameters required for decryption.
getDecryptionParameters() - Method in class org.apache.accumulo.core.spi.crypto.NoFileEncrypter
 
getDecryptionParams() - Method in class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
 
getDecryptionParams() - Method in interface org.apache.accumulo.core.spi.crypto.CryptoEnvironment
If decrypting files, get the params read from the file.
getDeepCopyDataSource(IteratorEnvironment) - Method in interface org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator.DataSource
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getDefaultBufferSize() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getDefaultExtension() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
getDefaultFormatter(Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
 
getDefaultInputTableConfig(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Returns the InputTableConfig for the configuration based on the properties set using the single-table input methods.
getDefaultRealm() - Static method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
getDefaultTableName(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.OutputConfigurator
Gets the default table name from the configuration.
getDefaultTableName(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
Gets the default table name from the configuration.
getDefaultTableName(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
Gets the default table name from the configuration.
getDefaultValue() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
Deprecated.
 
getDefaultValue() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getDefaultValue() - Method in enum org.apache.accumulo.core.conf.Property
Gets the default value for this property.
getDelay() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelections
 
getDelegationToken() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getDelegationToken
 
getDelegationToken() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getDelegationToken
 
getDelegationToken(DelegationTokenConfig) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Obtain a DelegationToken for use when Kerberos credentials cannot be used (e.g.
getDelegationToken(DelegationTokenConfig) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback<TDelegationToken>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback<TDelegationToken>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
getDelegationToken_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getDelegationToken_args(ManagerClientService.getDelegationToken_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
Performs a deep copy on other.
getDelegationToken_args(TInfo, TCredentials, TDelegationTokenConfig) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getDelegationToken_call(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback<TDelegationToken>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getDelegationToken_call
 
getDelegationToken_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getDelegationToken_result(ManagerClientService.getDelegationToken_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
Performs a deep copy on other.
getDelegationToken_result(TDelegationToken, ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getDeleted() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getDeletedFiles() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getDeletesIgnored() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getDependencies() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache.Loader
The cache blocks that this loader depends on.
getDepth() - Method in enum org.apache.accumulo.core.data.PartialKey
Gets the depth of this partial key.
getDerived(Function<PluginEnvironment.Configuration, T>) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Returns a derived value from this Configuration.
getDerived(Function<PluginEnvironment.Configuration, T>) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getDescription() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
Deprecated.
 
getDescription() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
getDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
getDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getDescription() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getDescription() - Method in enum org.apache.accumulo.core.conf.Property
Gets the description of this property.
getDescription() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getDescription() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
getDesiredRate() - Method in interface org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory.RateProvider
Calculate the current rate for the RateLimiter.
getDestinations() - Method in class org.apache.accumulo.core.data.LoadPlan
 
getDir() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
getDirName() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getDiskUsage() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
getDiskUsage() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getDiskUsage
 
getDiskUsage(Set<String>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets the number of bytes being used by the files for a set of tables.
getDiskUsage(Set<String>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getDiskUsage(Set<String>, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getDiskUsage(Set<String>, TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getDiskUsage(Set<String>, TCredentials, AsyncMethodCallback<List<TDiskUsage>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getDiskUsage(Set<String>, TCredentials, AsyncMethodCallback<List<TDiskUsage>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getDiskUsage_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getDiskUsage_args(Set<String>, TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getDiskUsage_args(ClientService.getDiskUsage_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
Performs a deep copy on other.
getDiskUsage_call(Set<String>, TCredentials, AsyncMethodCallback<List<TDiskUsage>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getDiskUsage_call
 
getDiskUsage_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getDiskUsage_result(List<TDiskUsage>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getDiskUsage_result(ClientService.getDiskUsage_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
Performs a deep copy on other.
getDocID(Key) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
getDocID(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getDuplicateReads() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getDurability() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getDurability() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
getDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
getE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
getE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
getEarlierEntries(long) - Method in interface org.apache.accumulo.core.fate.zookeeper.DistributedReadWriteLock.QueueLock
 
getEarlierEntries(long) - Method in class org.apache.accumulo.core.fate.zookeeper.FateLock
 
getEdits() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
getEditsIterator() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
getEditsSize() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
getElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getEmitted() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticateUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.bulkImportFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkTableClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.createLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getInstanceId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getSystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedSystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.isActive
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.ping
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticateUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.bulkImportFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeLocalUserPassword
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkNamespaceClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkTableClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.createLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.dropLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getDiskUsage
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getInstanceId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getRootTabletLocation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getSystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getUserAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedSystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getZooKeepers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.isActive
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.listLocalUsers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.ping
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.fails
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.success
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.throwsError
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.fails
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.success
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.throwsError
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.cancel
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionCompleted
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionFailed
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompactionJob
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getRunningCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.updateCompactionStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.cancel
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionCompleted
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionFailed
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompactionJob
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompletedCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getRunningCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.updateCompactionStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.cancel
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompaction
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompactionId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.cancel
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompaction
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompactionId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.beginFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.cancelFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.executeFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.finishFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.waitForFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.beginFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.cancelFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.executeFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.finishFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.waitForFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.drainReplicationTable
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getActiveTservers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getDelegationToken
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getManagerStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.initiateFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifySystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportSplitExtent
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportTabletStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setManagerGoalState
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdown
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdownTabletServer
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForBalance
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.drainReplicationTable
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getActiveTservers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getDelegationToken
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getManagerStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.initiateFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifySystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportSplitExtent
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportTabletStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setManagerGoalState
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdown
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdownTabletServer
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForBalance
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor.getServicerAddress
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Processor.getServicerAddress
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateKeyValues
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateLog
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateKeyValues
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateLog
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.cancelUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compactionJobFailed
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compactionJobFinished
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.contiuneGetSummaries
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getCompactionQueueInfo
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.reserveCompactionJob
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startGetSummaries
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startGetSummariesForPartition
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startGetSummariesFromFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.cancelUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compactionJobFailed
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compactionJobFinished
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.contiuneGetSummaries
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getCompactionQueueInfo
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.reserveCompactionJob
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startGetSummaries
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startGetSummariesForPartition
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startGetSummariesFromFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.closeMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.closeScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.continueMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.continueScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.getActiveScans
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.startMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.startScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.closeMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.closeScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.continueMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.continueScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.getActiveScans
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.startMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.startScan
 
getEncodedEndRow() - Method in exception org.apache.accumulo.core.metadata.TabletLocationState.BadLocationStateException
 
getEncrypter() - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule
 
getEncrypter() - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule
 
getEndKey() - Method in class org.apache.accumulo.core.data.Range
Gets the ending key, or null if the end is positive infinity.
getEndRow() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getEndRow() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Tablet
 
getEndRow() - Method in class org.apache.accumulo.core.data.LoadPlan.Destination
 
getEndRow() - Method in interface org.apache.accumulo.core.data.TabletId
 
getEndRow() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
getEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
getEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
getEndRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getEndRow() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getEndRow() - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment
The end row of the tablet for which a volume is being chosen.
getEndRow() - Method in class org.apache.accumulo.core.summary.Gatherer.RowRange
 
getEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getEntries() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getEntries() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
getEntriesLeft() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
getEntriesRead() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getEntriesRead() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getEntriesRead() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
getEntriesToBeCompacted() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getEntriesWritten() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getEntriesWritten() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getEntriesWritten() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
getEnvironment() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InitParameters
 
getEnvironment() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InputParameters
 
getEnvironment() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.InitParameters
 
getEnvironment() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getEphemeralOwner() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache.ZcStat
 
getEquivalent(SystemPermission) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
 
getEquivalent(TablePermission) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
 
getErrorDir() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getErrorServers() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getEstFileSize() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
getEstimatedEntries() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
getEstimatedEntries() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getEstimatedSize() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
getEstimatedSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
getEstimatedSize() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getEstNumEntries() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
getEvictedCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getEvictedCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the number of blocks that have been evicted during the lifetime of this cache.
getEvictionCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getEvictionCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the number of eviction runs that have occurred
getEx() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
getException(long) - Method in class org.apache.accumulo.core.fate.Fate
 
getExecutionHints() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getExecutionHints() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.DispatchParameters
 
getExecutionHints() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getExecutionHints() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
 
getExecutionHints() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getExecutionHints() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getExecutionHintsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getExecutionHintsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getExecutor() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionJob
 
getExecutor() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
getExecutorManager() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.InitParameters
 
getExecutorManager() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getExecutorName() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch
 
getExpirationDate() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getExpirationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getExpirationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getExportedProps(FileSystem, Path) - Static method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getExpression() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Accessor for the underlying byte string.
getExtent() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getExtent() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getExtent() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
Deprecated.
Gets the key extent of the environment.
getExtent() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getExtent() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
getExternalCompactionFinalStates() - Method in interface org.apache.accumulo.core.metadata.schema.Ample
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getExternalCompactions() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getExternalExecutor(String) - Method in interface org.apache.accumulo.core.spi.compaction.ExecutorManager
 
getExternalName() - Method in class org.apache.accumulo.core.util.compaction.CompactionExecutorIdImpl
 
getExtra() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getFail() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getFailedExtents() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getFailedExtentsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getFailures() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFailuresSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFamily() - Method in class org.apache.accumulo.core.data.Condition
Gets the column family of this condition.
getFetchedColumns() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Deprecated.
Returns the columns to be fetched for this configuration
getFetchedColumns() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getFetchedColumns() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getFetchedColumns() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
This method returns what column were fetched by a scan.
getFetchedColumns(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Gets the columns to be mapped over from this job.
getFetchedColumns(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Deprecated.
Gets the columns to be mapped over from this job.
getFetchedColumns(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Deprecated.
Gets the columns to be mapped over from this job.
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.TNextCompactionJob._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.MapFileInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyValue._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.DeadServer._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.RecoveryException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.WalEdits._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
 
getFieldValue(ClientService.authenticate_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
getFieldValue(ClientService.authenticate_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
getFieldValue(ClientService.authenticateUser_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
getFieldValue(ClientService.authenticateUser_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
getFieldValue(ClientService.bulkImportFiles_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getFieldValue(ClientService.bulkImportFiles_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
getFieldValue(ClientService.changeAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getFieldValue(ClientService.changeAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
getFieldValue(ClientService.changeLocalUserPassword_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getFieldValue(ClientService.changeLocalUserPassword_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
getFieldValue(ClientService.checkClass_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getFieldValue(ClientService.checkClass_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
getFieldValue(ClientService.checkNamespaceClass_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getFieldValue(ClientService.checkNamespaceClass_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
getFieldValue(ClientService.checkTableClass_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getFieldValue(ClientService.checkTableClass_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
getFieldValue(ClientService.createLocalUser_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getFieldValue(ClientService.createLocalUser_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
getFieldValue(ClientService.dropLocalUser_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
getFieldValue(ClientService.dropLocalUser_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
getFieldValue(ClientService.getConfiguration_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getFieldValue(ClientService.getConfiguration_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getFieldValue(ClientService.getDiskUsage_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getFieldValue(ClientService.getDiskUsage_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getFieldValue(ClientService.getInstanceId_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
getFieldValue(ClientService.getInstanceId_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
getFieldValue(ClientService.getNamespaceConfiguration_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getFieldValue(ClientService.getNamespaceConfiguration_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getFieldValue(ClientService.getNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getFieldValue(ClientService.getNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getFieldValue(ClientService.getRootTabletLocation_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
getFieldValue(ClientService.getRootTabletLocation_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
getFieldValue(ClientService.getSystemProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getFieldValue(ClientService.getSystemProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getFieldValue(ClientService.getTableConfiguration_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getFieldValue(ClientService.getTableConfiguration_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getFieldValue(ClientService.getTableProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getFieldValue(ClientService.getTableProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getFieldValue(ClientService.getUserAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getFieldValue(ClientService.getUserAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getFieldValue(ClientService.getVersionedNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getFieldValue(ClientService.getVersionedNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getFieldValue(ClientService.getVersionedSystemProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
getFieldValue(ClientService.getVersionedSystemProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
getFieldValue(ClientService.getVersionedTableProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getFieldValue(ClientService.getVersionedTableProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getFieldValue(ClientService.getZooKeepers_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
getFieldValue(ClientService.getZooKeepers_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
getFieldValue(ClientService.grantNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getFieldValue(ClientService.grantNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
getFieldValue(ClientService.grantSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getFieldValue(ClientService.grantSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
getFieldValue(ClientService.grantTablePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getFieldValue(ClientService.grantTablePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
getFieldValue(ClientService.hasNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getFieldValue(ClientService.hasNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
getFieldValue(ClientService.hasSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getFieldValue(ClientService.hasSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
getFieldValue(ClientService.hasTablePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getFieldValue(ClientService.hasTablePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
getFieldValue(ClientService.isActive_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
getFieldValue(ClientService.isActive_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
getFieldValue(ClientService.listLocalUsers_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
getFieldValue(ClientService.listLocalUsers_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getFieldValue(ClientService.ping_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
getFieldValue(ClientService.ping_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
getFieldValue(ClientService.revokeNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getFieldValue(ClientService.revokeNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
getFieldValue(ClientService.revokeSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getFieldValue(ClientService.revokeSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
getFieldValue(ClientService.revokeTablePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getFieldValue(ClientService.revokeTablePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
getFieldValue(TDiskUsage._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getFieldValue(ThriftConcurrentModificationException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
getFieldValue(ThriftNotActiveServiceException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
getFieldValue(ThriftSecurityException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
getFieldValue(ThriftTableOperationException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getFieldValue(ThriftTest.fails_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
getFieldValue(ThriftTest.fails_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
getFieldValue(ThriftTest.success_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
getFieldValue(ThriftTest.success_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
getFieldValue(ThriftTest.throwsError_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
getFieldValue(ThriftTest.throwsError_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
getFieldValue(TVersionedProperties._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
getFieldValue(CompactionCoordinatorService.cancel_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
getFieldValue(CompactionCoordinatorService.cancel_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
getFieldValue(CompactionCoordinatorService.compactionCompleted_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getFieldValue(CompactionCoordinatorService.compactionCompleted_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
getFieldValue(CompactionCoordinatorService.compactionFailed_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getFieldValue(CompactionCoordinatorService.compactionFailed_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
getFieldValue(CompactionCoordinatorService.getCompactionJob_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getFieldValue(CompactionCoordinatorService.getCompactionJob_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
getFieldValue(CompactionCoordinatorService.getCompletedCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getFieldValue(CompactionCoordinatorService.getCompletedCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
getFieldValue(CompactionCoordinatorService.getRunningCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getFieldValue(CompactionCoordinatorService.getRunningCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
getFieldValue(CompactionCoordinatorService.updateCompactionStatus_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getFieldValue(CompactionCoordinatorService.updateCompactionStatus_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
getFieldValue(CompactorService.cancel_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
getFieldValue(CompactorService.cancel_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
getFieldValue(CompactorService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getFieldValue(CompactorService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getFieldValue(CompactorService.getRunningCompaction_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getFieldValue(CompactorService.getRunningCompaction_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getFieldValue(CompactorService.getRunningCompactionId_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getFieldValue(CompactorService.getRunningCompactionId_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getFieldValue(TCompactionStatusUpdate._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getFieldValue(TExternalCompaction._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getFieldValue(TExternalCompactionList._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
getFieldValue(TNextCompactionJob._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
getFieldValue(UnknownCompactionIdException._Fields) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
getFieldValue(InitialMultiScan._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
getFieldValue(InitialScan._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
getFieldValue(IterInfo._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
getFieldValue(MapFileInfo._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.MapFileInfo
 
getFieldValue(MultiScanResult._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFieldValue(ScanResult._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
getFieldValue(TCMResult._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
getFieldValue(TColumn._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
getFieldValue(TCondition._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getFieldValue(TConditionalMutation._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getFieldValue(TConditionalSession._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
getFieldValue(TConstraintViolationSummary._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
getFieldValue(TKey._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getFieldValue(TKeyExtent._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
getFieldValue(TKeyValue._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
getFieldValue(TMutation._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getFieldValue(TRange._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
getFieldValue(TRowRange._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
getFieldValue(TSummaries._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getFieldValue(TSummarizerConfiguration._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getFieldValue(TSummary._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getFieldValue(TSummaryRequest._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getFieldValue(UpdateErrors._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getFieldValue(GcCycleStats._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getFieldValue(GCMonitorService.getStatus_args._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getFieldValue(GCMonitorService.getStatus_result._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getFieldValue(GCStatus._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getFieldValue(DeadServer._Fields) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
getFieldValue(FateService.beginFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
getFieldValue(FateService.beginFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
getFieldValue(FateService.cancelFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
getFieldValue(FateService.cancelFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
getFieldValue(FateService.executeFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getFieldValue(FateService.executeFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
getFieldValue(FateService.finishFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
getFieldValue(FateService.finishFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
getFieldValue(FateService.waitForFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
getFieldValue(FateService.waitForFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getFieldValue(ManagerClientService.drainReplicationTable_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
getFieldValue(ManagerClientService.drainReplicationTable_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
getFieldValue(ManagerClientService.getActiveTservers_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getFieldValue(ManagerClientService.getActiveTservers_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getFieldValue(ManagerClientService.getDelegationToken_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getFieldValue(ManagerClientService.getDelegationToken_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getFieldValue(ManagerClientService.getManagerStats_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getFieldValue(ManagerClientService.getManagerStats_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getFieldValue(ManagerClientService.initiateFlush_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
getFieldValue(ManagerClientService.initiateFlush_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getFieldValue(ManagerClientService.modifyNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getFieldValue(ManagerClientService.modifyNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getFieldValue(ManagerClientService.modifySystemProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
getFieldValue(ManagerClientService.modifySystemProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getFieldValue(ManagerClientService.modifyTableProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getFieldValue(ManagerClientService.modifyTableProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getFieldValue(ManagerClientService.removeNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getFieldValue(ManagerClientService.removeNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
getFieldValue(ManagerClientService.removeSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
getFieldValue(ManagerClientService.removeSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
getFieldValue(ManagerClientService.removeTableProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getFieldValue(ManagerClientService.removeTableProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
getFieldValue(ManagerClientService.reportSplitExtent_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getFieldValue(ManagerClientService.reportTabletStatus_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getFieldValue(ManagerClientService.setManagerGoalState_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
getFieldValue(ManagerClientService.setManagerGoalState_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
getFieldValue(ManagerClientService.setNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getFieldValue(ManagerClientService.setNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getFieldValue(ManagerClientService.setSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getFieldValue(ManagerClientService.setSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
getFieldValue(ManagerClientService.setTableProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getFieldValue(ManagerClientService.setTableProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getFieldValue(ManagerClientService.shutdown_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
getFieldValue(ManagerClientService.shutdown_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
getFieldValue(ManagerClientService.shutdownTabletServer_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
getFieldValue(ManagerClientService.shutdownTabletServer_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
getFieldValue(ManagerClientService.waitForBalance_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
getFieldValue(ManagerClientService.waitForBalance_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
getFieldValue(ManagerClientService.waitForFlush_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getFieldValue(ManagerClientService.waitForFlush_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
getFieldValue(ManagerMonitorInfo._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getFieldValue(RecoveryException._Fields) - Method in exception org.apache.accumulo.core.manager.thrift.RecoveryException
 
getFieldValue(TabletSplit._Fields) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getFieldValue(ThriftPropertyException._Fields) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
getFieldValue(BulkImportStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
getFieldValue(Compacting._Fields) - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getFieldValue(RecoveryStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getFieldValue(TableInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getFieldValue(TabletServerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getFieldValue(KeyValues._Fields) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
getFieldValue(RemoteReplicationException._Fields) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
getFieldValue(ReplicationCoordinator.getServicerAddress_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
getFieldValue(ReplicationCoordinator.getServicerAddress_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
getFieldValue(ReplicationCoordinatorException._Fields) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
getFieldValue(ReplicationServicer.replicateKeyValues_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
getFieldValue(ReplicationServicer.replicateKeyValues_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
getFieldValue(ReplicationServicer.replicateLog_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
getFieldValue(ReplicationServicer.replicateLog_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
getFieldValue(WalEdits._Fields) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
 
getFieldValue(TAuthenticationKey._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getFieldValue(TAuthenticationTokenIdentifier._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getFieldValue(TCredentials._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getFieldValue(TDelegationToken._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
getFieldValue(TDelegationTokenConfig._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
getFieldValue(ActionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getFieldValue(ActiveCompaction._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getFieldValue(ActiveScan._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getFieldValue(ConstraintViolationException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
 
getFieldValue(InputFile._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getFieldValue(IteratorConfig._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getFieldValue(NoSuchScanIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
getFieldValue(NotServingTabletException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
getFieldValue(ScanServerBusyException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException
 
getFieldValue(TabletClientService.applyUpdates_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getFieldValue(TabletClientService.bulkImport_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getFieldValue(TabletClientService.bulkImport_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getFieldValue(TabletClientService.cancelUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
getFieldValue(TabletClientService.cancelUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result
 
getFieldValue(TabletClientService.chop_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getFieldValue(TabletClientService.closeConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
getFieldValue(TabletClientService.closeUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
getFieldValue(TabletClientService.closeUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
getFieldValue(TabletClientService.compact_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getFieldValue(TabletClientService.compactionJobFailed_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
getFieldValue(TabletClientService.compactionJobFinished_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
getFieldValue(TabletClientService.conditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getFieldValue(TabletClientService.conditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getFieldValue(TabletClientService.contiuneGetSummaries_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
getFieldValue(TabletClientService.contiuneGetSummaries_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
getFieldValue(TabletClientService.fastHalt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
getFieldValue(TabletClientService.flush_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getFieldValue(TabletClientService.flushTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getFieldValue(TabletClientService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
getFieldValue(TabletClientService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getFieldValue(TabletClientService.getActiveLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
getFieldValue(TabletClientService.getActiveLogs_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
getFieldValue(TabletClientService.getCompactionQueueInfo_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
getFieldValue(TabletClientService.getCompactionQueueInfo_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
getFieldValue(TabletClientService.getHistoricalStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
getFieldValue(TabletClientService.getHistoricalStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
getFieldValue(TabletClientService.getTabletServerStatus_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
getFieldValue(TabletClientService.getTabletServerStatus_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
getFieldValue(TabletClientService.getTabletStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getFieldValue(TabletClientService.getTabletStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getFieldValue(TabletClientService.halt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
getFieldValue(TabletClientService.halt_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
getFieldValue(TabletClientService.invalidateConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
getFieldValue(TabletClientService.invalidateConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
 
getFieldValue(TabletClientService.loadFiles_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
getFieldValue(TabletClientService.loadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getFieldValue(TabletClientService.removeLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getFieldValue(TabletClientService.reserveCompactionJob_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
getFieldValue(TabletClientService.reserveCompactionJob_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
getFieldValue(TabletClientService.splitTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getFieldValue(TabletClientService.splitTablet_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
getFieldValue(TabletClientService.startConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getFieldValue(TabletClientService.startConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
getFieldValue(TabletClientService.startGetSummaries_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
getFieldValue(TabletClientService.startGetSummaries_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
getFieldValue(TabletClientService.startGetSummariesForPartition_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
getFieldValue(TabletClientService.startGetSummariesForPartition_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
getFieldValue(TabletClientService.startGetSummariesFromFiles_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
getFieldValue(TabletClientService.startGetSummariesFromFiles_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result
 
getFieldValue(TabletClientService.startUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
getFieldValue(TabletClientService.startUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
getFieldValue(TabletClientService.unloadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getFieldValue(TabletClientService.update_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getFieldValue(TabletClientService.update_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getFieldValue(TabletScanClientService.closeMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
getFieldValue(TabletScanClientService.closeMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
getFieldValue(TabletScanClientService.closeScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
getFieldValue(TabletScanClientService.continueMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
getFieldValue(TabletScanClientService.continueMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
getFieldValue(TabletScanClientService.continueScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
getFieldValue(TabletScanClientService.continueScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
getFieldValue(TabletScanClientService.getActiveScans_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
getFieldValue(TabletScanClientService.getActiveScans_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
getFieldValue(TabletScanClientService.startMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getFieldValue(TabletScanClientService.startMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
getFieldValue(TabletScanClientService.startScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getFieldValue(TabletScanClientService.startScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
getFieldValue(TabletStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getFieldValue(TCompactionQueueSummary._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
getFieldValue(TCompactionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
getFieldValue(TExternalCompactionJob._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getFieldValue(TIteratorSetting._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getFieldValue(TooManyFilesException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
 
getFieldValue(TSampleNotPresentException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
 
getFieldValue(TSamplerConfiguration._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
getFieldValue(TInfo._Fields) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
getFile(Key) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
Deprecated.
 
getFile(Key, Text) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
Extract the file name from the row suffix into the given Text
getFile(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
Deprecated.
 
getFile(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.StatusSection
Deprecated.
Extract the file name from the row suffix into the given Text
getFile(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.WorkSection
Deprecated.
 
getFileDecrypter(CryptoEnvironment) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
getFileDecrypter(CryptoEnvironment) - Method in interface org.apache.accumulo.core.spi.crypto.CryptoService
Initialize the FileDecrypter for the environment and return.
getFileDecrypter(CryptoEnvironment) - Method in class org.apache.accumulo.core.spi.crypto.NoCryptoService
 
getFileDecrypter(CryptoService, CryptoEnvironment.Scope, TableId, DataInputStream) - Static method in class org.apache.accumulo.core.crypto.CryptoUtils
Read the decryption parameters from the DataInputStream and get the FileDecrypter associated with the provided CryptoService and CryptoEnvironment.Scope.
getFileEncrypter(CryptoEnvironment) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
getFileEncrypter(CryptoEnvironment) - Method in interface org.apache.accumulo.core.spi.crypto.CryptoService
Initialize the FileEncrypter for the environment and return.
getFileEncrypter(CryptoEnvironment) - Method in class org.apache.accumulo.core.spi.crypto.NoCryptoService
 
getFileLenCache() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getFilename() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getFilename() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
getFileName() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
getFileName() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
getFileName() - Method in class org.apache.accumulo.core.data.LoadPlan.Destination
 
getFileName() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getFileName() - Method in class org.apache.accumulo.core.metadata.TabletFile.FileParts
 
getFileName() - Method in class org.apache.accumulo.core.metadata.TabletFile
 
getFilenames() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getFilenamesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getFilenamesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getFilePath() - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
getFiles() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Mapping
 
getFiles() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getFiles() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getFiles() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionJob
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getFiles() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
getFilesContaining() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getFilesExceeding() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getFilesIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getFilesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getFileSize() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getFileSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
getFileSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
getFileSize(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.FileOperations
 
getFileSize(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
 
getFileSize(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
getFilesLarge() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getFilesMap() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getFilesSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getFileStatistics() - Method in class org.apache.accumulo.core.client.summary.Summary
 
getFilesToCompact() - Method in class org.apache.accumulo.core.client.admin.compaction.CompactionSelector.Selection
 
getFileSystem() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getFileSystem() - Method in interface org.apache.accumulo.core.volume.Volume
A FileSystem that Accumulo will use
getFileSystem() - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
getFinalState() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getFinished() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getFirst() - Method in class org.apache.accumulo.core.util.Pair
 
getFirstKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getFirstKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getFirstKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getFirstKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getFirstKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
getFirstKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getFixedMemoryAsBytes(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Interprets a string specifying bytes.
getFlush() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getFlushes() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getFlushes() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getFlushId() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getFlushID() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getFlushs() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getFormatter(Class<? extends Formatter>, Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
 
getFormatter(String) - Method in class org.apache.accumulo.core.file.rfile.PrintInfo
 
getFraction(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Interprets a string specifying a fraction.
getFraction(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.FRACTION, interpreting the value properly.
getFreeSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the current size of this cache.
getFreeSpace(String) - Method in class org.apache.accumulo.core.spi.fs.SpaceAwareVolumeChooser
 
getFullScans() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFullScansIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFullScansSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFullyQualifiedCallerName() - Method in class org.apache.accumulo.core.logging.ConditionalLogger
 
getFullyQualifiedOption(String) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.InitParameters
 
getFullyQualifiedOption(String) - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getFullyQualifiedPropertyPrefix(String) - Static method in class org.apache.accumulo.core.spi.cache.BlockCacheManager
Deprecated.
since 2.1.0 because this method does not support scan servers, only tservers. Use BlockCacheManager.Configuration.getProperties(String, CacheType) instead.
getFullyQualifiedPropertyPrefix(String, CacheType) - Static method in class org.apache.accumulo.core.spi.cache.BlockCacheManager
Deprecated.
since 2.1.0 because this method does not support scan servers, only tservers. Use BlockCacheManager.Configuration.getProperties(String, CacheType) instead.
getFullyQualifiedPropertyPrefix(Property, String) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getFullyQualifiedPropertyPrefix(Property, String, CacheType) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getFutureServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getGcCandidates(Ample.DataLevel) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
 
getGoal() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getGoalState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getGroup() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerInfo
 
getHadoopConf() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve the hadoop configuration
getHadoopConf() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getHadoopConf() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getHeaders() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
getHeadersSize() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
 
getHeldLocks() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getHints() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.SelectorParameters
 
getHistoricalStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
 
getHistoricalStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
 
getHistoricalStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getHistoricalStats(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getHistoricalStats(TInfo, TCredentials, AsyncMethodCallback<TabletStats>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getHistoricalStats(TInfo, TCredentials, AsyncMethodCallback<TabletStats>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getHistoricalStats_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
getHistoricalStats_args(TabletClientService.getHistoricalStats_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
Performs a deep copy on other.
getHistoricalStats_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
getHistoricalStats_call(TInfo, TCredentials, AsyncMethodCallback<TabletStats>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getHistoricalStats_call
 
getHistoricalStats_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
getHistoricalStats_result(TabletClientService.getHistoricalStats_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
Performs a deep copy on other.
getHistoricalStats_result(TabletStats, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
getHitRatio() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getHoldTime() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getHoldTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getHoldTime() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getHost() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
Return the host where the compaction is running.
getHost() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getHost() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
getHost() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getHost() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getHost() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletServerId
 
getHost() - Method in class org.apache.accumulo.core.util.HostAndPort
Returns the portion of this HostAndPort instance that should represent the hostname or IPv4/IPv6 literal.
getHostAndPort() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getHostAndPort() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getHostPort() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getHostPort() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getHostPortSession() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getHostPortSession() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getHostPortString(HostAndPort) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
Utility for returning the address of a service in the form host:port
getId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getId() - Method in enum org.apache.accumulo.core.security.NamespacePermission
Gets the byte ID of this permission.
getId() - Method in enum org.apache.accumulo.core.security.SystemPermission
Gets the byte ID of this permission.
getId() - Method in enum org.apache.accumulo.core.security.TablePermission
Gets the byte ID of this permission.
getIdentifier() - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
The identifier for this token, may be null.
getIdentifier() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
getIdleTime() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getIdleTime() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getIdleTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getIdleTimeStats() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
Returns statistics about the time between running.
getIdleTimeStats(long) - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
This method is similar to ScanInfo.getIdleTimeStats(), but it also includes the time period between the last run time and now in the stats.
getIds() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionServices
 
getIdtoNameMap() - Method in class org.apache.accumulo.core.util.tables.TableMap
 
getIdToNameMap(ClientContext) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Return sorted map with key = ID, value = namespaceName
getIgnored() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getInaccurate() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getIndex() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getIndex(Supplier<BlockIndex>) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getIndex(Supplier<T>) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
getIndex(Supplier<T>) - Method in interface org.apache.accumulo.core.spi.cache.CacheEntry
Optionally cache what is returned by the supplier along with this cache entry.
getIndex(CachableBlockFile.CachedBlockRead, MultiLevelIndex.IndexEntry) - Static method in class org.apache.accumulo.core.file.rfile.BlockIndex
 
getIndexCache() - Method in class org.apache.accumulo.core.file.blockfile.impl.BasicCacheProvider
 
getIndexCache() - Method in interface org.apache.accumulo.core.file.blockfile.impl.CacheProvider
 
getIndexCache() - Method in class org.apache.accumulo.core.file.blockfile.impl.ScanCacheProvider
 
getIndexCacheHits() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getIndexCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getIndexCacheHits() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getIndexCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getIndexCacheRequests() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getIndexCacheRequests() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getIndexCacheUsage() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch
 
getIndexInfo(Map<Integer, Long>, Map<Integer, Long>) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
getIngestByteRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getIngestByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getIngestByteRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getIngestRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getIngestRate() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getIngestRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getIngestRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getIngestRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getIngestRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getInitiallySelecteAll() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getInitialTableState() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Return value indicating whether table is to be created in offline or online mode.
getInputFiles() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getInputFiles() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InputParameters
 
getInputFiles() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getInputFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputFilesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputStream() - Method in class org.apache.accumulo.core.client.rfile.RFileSource
 
getInputTableConfig(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Returns the InputTableConfig for the given table
getInputTableConfig(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Fetches a InputTableConfig that has been set on the configuration for a specific table.
getInputTableConfig(JobContext, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Fetches a InputTableConfig that has been set on the configuration for a specific table.
getInputTableConfigs(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Returns all InputTableConfig objects associated with this job.
getInputTableConfigs(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Fetches all InputTableConfigs that have been set on the given Hadoop job.
getInputTableConfigs(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Fetches all InputTableConfigs that have been set on the given job.
getInputTableName(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Sets the name of the input table, over which this job will scan.
getInputTableName(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Deprecated.
Gets the table name from the configuration.
getInputTableName(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Deprecated.
Gets the table name from the configuration.
getInstance() - Method in class org.apache.accumulo.core.client.Connector
Deprecated.
Accessor method for internal instance object.
getInstance() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
since 1.7.0, use getInstance(ClientConfiguration) instead.
getInstance() - Method in class org.apache.accumulo.core.clientImpl.ConnectorImpl
Deprecated.
 
getInstance() - Static method in class org.apache.accumulo.core.conf.DefaultConfiguration
Gets a default configuration.
getInstance() - Static method in class org.apache.accumulo.core.file.FileOperations
 
getInstance(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
Initializes an Accumulo Instance based on the configuration.
getInstance(ClientConfiguration) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheManagerFactory
Get the BlockCacheFactory specified by the property 'tserver.cache.factory.class' using the AccumuloVFSClassLoader
getInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory
Get the singleton instance of the SharedRateLimiterFactory.
getInstance(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Initializes an Accumulo Instance based on the configuration.
getInstance(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
Initializes an Accumulo Instance based on the configuration.
getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Initializes an Accumulo Instance based on the configuration.
getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
Initializes an Accumulo Instance based on the configuration.
getInstanceId() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getInstanceId
 
getInstanceId() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getInstanceId
 
getInstanceId() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Returns a unique ID object that identifies this instance of accumulo.
getInstanceId() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getInstanceId() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getInstanceId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getInstanceId() - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getInstanceId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getInstanceId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getInstanceId(AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getInstanceId(AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getInstanceID() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Deprecated.
getInstanceID() - Method in interface org.apache.accumulo.core.client.Instance
Deprecated.
Returns a unique string that identifies this instance of accumulo.
getInstanceID() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
 
getInstanceID() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns a unique string that identifies this instance of accumulo.
getInstanceID() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
Deprecated.
getInstanceID(ZooCache, String) - Static method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getInstanceId_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
getInstanceId_args(ClientService.getInstanceId_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
Performs a deep copy on other.
getInstanceId_call(AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getInstanceId_call
 
getInstanceId_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
getInstanceId_result(String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
getInstanceId_result(ClientService.getInstanceId_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
Performs a deep copy on other.
getInstanceName() - Method in interface org.apache.accumulo.core.client.Instance
Deprecated.
Returns the instance name given at system initialization time.
getInstanceName() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getInstanceName() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
 
getInstanceName() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns the instance name given at system initialization time.
getInstanceName() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getInstanceName() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getInt(KT) - Method in class org.apache.accumulo.core.util.MapCounter
 
getInteger(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getIssueDate() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getIssueDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getIterator() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroup
 
getIteratorClass() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the name of the class that implements the iterator.
getIteratorClass() - Method in interface org.apache.accumulo.core.spi.common.IteratorConfiguration
 
getIteratorClass() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getIterators() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getIterators() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getIterators() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Deprecated.
Returns the iterators to be set on this configuration
getIterators() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getIterators() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getIterators() - Method in class org.apache.accumulo.core.data.Condition
Gets the iterators for this condition.
getIterators() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getIterators() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIterators(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
getIterators(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Deprecated.
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
getIterators(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Deprecated.
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
getIteratorSamplerConfiguration() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getIteratorScope() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Return the executed scope of the Iterator.
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Get the settings for an iterator.
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Get the settings for an iterator.
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
getIteratorSettings() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getIteratorsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIteratorsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIterName() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
getJob() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getJob() - Method in class org.apache.accumulo.core.compaction.thrift.TNextCompactionJob
 
getJob() - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
getJobFiles() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getJobs() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlan
Return the set of jobs this plan will submit for compaction.
getJobs() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlanImpl
 
getKerberosServerPrimary() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The 'primary' component from the Kerberos principals that servers are configured to use.
getKey() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
Deprecated.
 
getKey() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getKey() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getKey() - Method in enum org.apache.accumulo.core.conf.Property
Gets the key (string) for this property.
getKey() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
getKey() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getKey() - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
getKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getKeyExtent(TableId) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Mapping
 
getKeyId() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getKeyId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getKeyId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getKeyPrefix() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates the prefix of keys that will be transformed by this iterator.
getKeys() - Method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
 
getKeys(Configuration) - Static method in class org.apache.accumulo.core.conf.HadoopCredentialProvider
Attempt to extract all aliases from any configured CredentialProviders.
getKeyStorePass() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getKeyStorePath() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getKeyStoreType() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getKeytab() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
The keytab file used to perform Kerberos login.
getKeyValues() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getKeyValues() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
getKeyValuesIterator() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
getKeyValuesSize() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
 
getKind() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getKind() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getKind() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionJob
 
getKind() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getKind() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getKind() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
getKVCount() - Method in class org.apache.accumulo.core.client.RowIterator
Get a count of the total number of entries in all rows read so far.
getLarge() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getLast() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getLast() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getLastColumnFamilies() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroupSeekCache
 
getLastContact() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getLastContact() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLastContact() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getLastContactTime() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getLastContactTime() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getLastKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getLastKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getLastKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getLastKey() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
getLastKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getLastKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
getLastKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getLastRunTime() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
If the scan has run, returns the last run time.
getLastServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getLastStatus() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
getLastUsed() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroupSeekCache
 
getLength() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
This implementation of length is only an estimate, it does not provide exact values.
getLength() - Method in class org.apache.accumulo.core.client.rfile.RFileSource
 
getLength() - Method in class org.apache.accumulo.core.clientImpl.mapreduce.BatchInputSplit
Deprecated.
This implementation of length is only an estimate, it does not provide exact values.
getLength() - Method in class org.apache.accumulo.core.data.Key
Returns the sums of the lengths of the row, column family, column qualifier, and column visibility.
getLength() - Method in class org.apache.accumulo.core.dataImpl.ComparableBytes
 
getLength() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
getLength() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
getLength() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
 
getLength() - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
getLength() - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
getLifetime() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
getLiveTServers(ClientContext) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
Get the tservers that are live from ZK.
getLoadBalancerClassNameForTable(TableId) - Method in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
getLoaded() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getLocalityGroup() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getLocalityGroup() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getLocalityGroup() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getLocalityGroupCF() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getLocalityGroups(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets the locality groups currently set for a table.
getLocalityGroups(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getLocalityGroups(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
getLocalityGroupsIgnoringErrors(AccumuloConfiguration, TableId) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
getLocation() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getLocation() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getLocation(ClientContext) - Static method in class org.apache.accumulo.core.util.MonitorUtil
 
getLocationless() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocations
 
getLocationProvider() - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
getLocations() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getLocations() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocations
 
getLocator(ClientContext, TableId) - Static method in class org.apache.accumulo.core.clientImpl.TabletLocator
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getLockData(ServiceLock.ServiceLockPath) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
 
getLockData(ZooCache, ServiceLock.ServiceLockPath, ZooCache.ZcStat) - Static method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
getLockData(ZooKeeper, ServiceLock.ServiceLockPath) - Static method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
getLockID() - Method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
getLockName() - Method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
getLockPath() - Method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
getLogInterval() - Method in class org.apache.accumulo.core.util.Retry
 
getLogLevel() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getLogLevel(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
Gets the log level from this configuration.
getLogLevel(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Gets the log level from this configuration.
getLogLevel(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
Gets the log level from this configuration.
getLogLevel(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Gets the log level from this configuration.
getLogLevel(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
Gets the log level from this configuration.
getLogs() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getLogSorts() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLogSortsIterator() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLogSortsSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLogsToWatch() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
getLogsToWatchIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
getLogsToWatchSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
getLookups() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getLookups() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getLookups() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getMajors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getMajors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getManagerConnection(Logger, ThriftClientTypes<C>, ClientContext) - Method in interface org.apache.accumulo.core.rpc.clients.ManagerClient
 
getManagerDrain(TInfo, TCredentials, String, Set<String>) - Method in class org.apache.accumulo.core.clientImpl.ReplicationOperationsImpl
Deprecated.
 
getManagerLocations() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Returns the location(s) of the accumulo manager and any redundant servers.
getManagerLocations() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns the location(s) of the accumulo manager and any redundant servers.
getManagerLocations() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getManagerLocations(ZooCache, String) - Static method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getManagerStats() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getManagerStats
 
getManagerStats() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getManagerStats
 
getManagerStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
getManagerStats(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
getManagerStats(TInfo, TCredentials, AsyncMethodCallback<ManagerMonitorInfo>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
getManagerStats(TInfo, TCredentials, AsyncMethodCallback<ManagerMonitorInfo>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
getManagerStats_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getManagerStats_args(ManagerClientService.getManagerStats_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
Performs a deep copy on other.
getManagerStats_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getManagerStats_call(TInfo, TCredentials, AsyncMethodCallback<ManagerMonitorInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getManagerStats_call
 
getManagerStats_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getManagerStats_result(ManagerClientService.getManagerStats_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
Performs a deep copy on other.
getManagerStats_result(ManagerMonitorInfo, ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getMapConcurrencyLevel() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMapLoadFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMask() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getMasterLocations() - Method in interface org.apache.accumulo.core.client.Instance
Deprecated.
Returns the location(s) of the accumulo manager and any redundant servers.
getMasterLocations() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
 
getMaxEntrySize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getMaxEntrySize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.SynchronousLoadingBlockCache
Get the maximum size of an individual cache entry.
getMaxFilesPerTablet() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets the maximum number of files per tablet from this configuration.
getMaxHeapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getMaxHeapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getMaxHeapSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getMaxHeapSize() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Get the maximum amount of on heap memory this cache will use.
getMaxLatency(TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxLoops() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getMaxMemory() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxMigrations() - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
The maximum number of migrations to perform in a single pass.
getMaxMigrations() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getMaxOutstandingMigrations() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getMaxRow(String, Authorizations, Text, boolean, Text, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Finds the max row within a given range.
getMaxRow(String, Authorizations, Text, boolean, Text, boolean) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getMaxSize() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Get the maximum size of this cache.
getMaxSize(CacheType) - Method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getMaxSize(CacheType) - Method in interface org.apache.accumulo.core.spi.cache.BlockCacheManager.Configuration
Before Accumulo's cache implementation was configurable, its built in caches had a configurable size.
getMaxThreads() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor.Config
 
getMaxWriteThreads() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxWriteThreads() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getMechanism() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The SASL mechanism to use for authentication
getMechanismName() - Method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
 
getMemoryAsBytes(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Interprets a string specifying a Memory type which is specified as a long integer followed by an optional B (bytes), K (KB), M (MB), G (GB) or % (percentage).
getMemoryFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMessage() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getMessage() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getMessage() - Method in exception org.apache.accumulo.core.security.VisibilityParseException
 
getMetaBlock(long, long, long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
getMetaBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
It is intended that once the BlockRead object is returned to the caller, that the caller will read the entire block and then call close on the BlockRead class.
getMetaBlock(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Stream access to a Meta Block.
getMetaBlockRawSize(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
getMetadataEntry() - Method in interface org.apache.accumulo.core.gc.Reference
Get the exact string stored in the metadata table for this file or directory.
getMetadataEntry() - Method in class org.apache.accumulo.core.gc.ReferenceFile
 
getMetadataFileEntry() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getMetadataLocationEntries(SortedMap<Key, Value>) - Static method in class org.apache.accumulo.core.metadata.MetadataLocationObtainer
 
getMetaInsert() - Method in class org.apache.accumulo.core.metadata.TabletFile
Return a string for inserting a new tablet file.
getMetaInsertText() - Method in class org.apache.accumulo.core.metadata.TabletFile
Return a new Text object of TabletFile.getMetaInsert()
getMetaStore(String) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getMetaStore(String) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getMetaStore(String) - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
getMetaStore(String) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getMetaUpdateDelete() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
Return the exact string that is stored in the metadata table.
getMetaUpdateDeleteText() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
Return a new Text object of StoredTabletFile.getMetaUpdateDelete()
getMetricFields() - Method in interface org.apache.accumulo.core.metrics.MetricsProducer
Returns a new mutable mapping of metric field value to metric field name.
getMetrics() - Method in interface org.apache.accumulo.core.file.rfile.MetricsGatherer
 
getMetrics() - Method in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
getMigrations(Map<TabletServerId, TServerStatus>, List<TabletMigration>) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
getMinFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMinors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getMinors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getMissCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getMissing() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getMissRatio() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getMode() - Static method in class org.apache.accumulo.core.singletons.SingletonManager
 
getModulus() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
getMultiFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMutation() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
 
getMutation() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getMutations() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletServerMutations
 
getMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getMutationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getMutationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getMutationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getMzxid() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache.ZcStat
 
getName() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the iterator's name.
getName() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
getName() - Method in interface org.apache.accumulo.core.fate.ReadOnlyRepo
 
getName() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
getName() - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
Returns the name of the compression algorithm.
getName() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getName() - Method in class org.apache.accumulo.core.logging.ConditionalLogger
 
getName() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getName() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getName() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getName() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getName() - Method in interface org.apache.accumulo.core.spi.common.IteratorConfiguration
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getName() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getName() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor.Config
 
getName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getNamedOptions() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getNameFromIp(String) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceConfiguration
 
getNamespaceConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getNamespaceConfiguration(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getNamespaceConfiguration(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getNamespaceConfiguration(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getNamespaceConfiguration_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getNamespaceConfiguration_args(ClientService.getNamespaceConfiguration_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
Performs a deep copy on other.
getNamespaceConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getNamespaceConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
 
getNamespaceConfiguration_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getNamespaceConfiguration_result(Map<String, String>, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getNamespaceConfiguration_result(ClientService.getNamespaceConfiguration_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
Performs a deep copy on other.
getNamespaceId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getNamespaceId(ClientContext, String) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Look for namespace ID in ZK.
getNamespaceId(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getNamespaceId(TableId) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Returns the namespace id for a given table ID.
getNamespaceName() - Method in exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
getNamespaceName() - Method in exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
getNamespaceName(ClientContext, NamespaceId) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Look for namespace name in ZK.
getNamespaceProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceProperties
 
getNamespaceProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceProperties
 
getNamespaceProperties(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Gets properties specific to this namespace.
getNamespaceProperties(String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
getNamespaceProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getNamespaceProperties(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getNamespaceProperties(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getNamespaceProperties(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getNamespaceProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getNamespaceProperties_args(ClientService.getNamespaceProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
Performs a deep copy on other.
getNamespaceProperties_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getNamespaceProperties_call(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceProperties_call
 
getNamespaceProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getNamespaceProperties_result(Map<String, String>, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getNamespaceProperties_result(ClientService.getNamespaceProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
Performs a deep copy on other.
getNameToIdMap() - Method in class org.apache.accumulo.core.util.tables.TableMap
 
getNameToIdMap(ClientContext) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Return sorted map with key = namespaceName, value = ID
getNewDataSource() - Method in interface org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator.DataSource
 
getNewFileExtension(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.FileOperations
 
getNewTablets() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getNewTabletServer() - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
getNewTabletsIterator() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getNewTabletsSize() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getNewZooCache(String, int) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCacheFactory
Always return a new ZooCache.
getNextFiles() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getNextKeyHint(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
 
getNextKeyHint(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
Whenever the subclass returns AdvanceResult.USE_HINT from its filter predicate, this method will be called to see how far to advance the source iterator.
getNormalizedPath() - Method in class org.apache.accumulo.core.metadata.TabletFile.FileParts
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
getNum() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
getNumEntries() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getNumEntries() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getNumEntries() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getNumEntries() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getNumLGSeeked() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroupSeekCache
 
getNumThreads(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Get the number of threads from string property.
getObject(Key) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnToClassMapping
 
getOffset() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getOldPrevEndRow() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getOldTablet() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getOldTabletServer() - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
getOnlineTabletCount() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getOnlineTabletCount() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getOnlineTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getOnlineTabletsForTable(TabletServerId, TableId) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getOnlineTabletsForTable(TabletServerId, TableId) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
getOobCheckMillis() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getOp() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getOp() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
getOptions() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InitParameters
 
getOptions() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.InitParameters
 
getOptions() - Method in class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
Deprecated.
 
getOptions() - Method in class org.apache.accumulo.core.client.admin.PluginConfig
 
getOptions() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the configuration parameters for this iterator.
getOptions() - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
getOptions() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
 
getOptions() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getOptions() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getOptions() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
getOptions() - Method in interface org.apache.accumulo.core.spi.common.IteratorConfiguration
 
getOptions() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.InitParameters
 
getOptions() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.InitParameters
 
getOptions() - Method in interface org.apache.accumulo.core.spi.metrics.MeterRegistryFactory.InitParameters
Get the configured metrics properties passed as general.custom.metrics.opts The returned map is the stripped names with general.custom.metrics.opts removed.
getOptions() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.InitParameters
 
getOptions() - Method in interface org.apache.accumulo.core.spi.scan.ScanPrioritizer.CreateParameters
 
getOptions() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.InitParameters
 
getOptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
getOptions() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getOptions() - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
getOptionsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getOptionsSize() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getOptionsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
 
getOsLoad() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getOsLoad() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getOsLoad() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
 
getOutputFile() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getOutputFile() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getOutputStream() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getOverhead() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getOverrides() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getOverrides() - Method in class org.apache.accumulo.core.cli.ConfigOpts
 
getOverrides() - Method in class org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.Overrides
 
getOverrides() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getOverrides(List<String>) - Static method in class org.apache.accumulo.core.cli.ConfigOpts
 
getOverridesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getParent() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
get a parent configuration or null if it does not exist.
getParent() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getParseTree() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Gets the parse tree for this column visibility.
getPartition(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getPartition(Key, Writable, int) - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
Deprecated.
 
getPartition(Text, Writable, int) - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
Deprecated.
 
getPartitioner() - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
getPartitioner() - Method in class org.apache.accumulo.core.spi.balancer.RegexGroupBalancer
 
getPartNextKey() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getPartScan() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getPassword() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
getPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getPassword() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
getPassword(SecretManager<T>, T) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
Generate the password from the provided SecretManager and TokenIdentifier.
getPath() - Method in class org.apache.accumulo.core.gc.GcCandidate
 
getPath() - Method in class org.apache.accumulo.core.metadata.TabletFile
 
getPath(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.PATH.
getPathStr() - Method in class org.apache.accumulo.core.metadata.TabletFile
Return a string for opening and reading the tablet file.
getPeerName() - Method in class org.apache.accumulo.core.replication.ReplicationTarget
Deprecated.
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Gets the permission matching the given byte ID.
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.SystemPermission
Gets the permission matching the given byte ID.
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.TablePermission
Gets the permission matching the given byte ID.
getPlanners() - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
getPluginEnv() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Returns an object containing information about the server where this iterator was run.
getPoolBuilder(String) - Method in class org.apache.accumulo.core.util.threads.ThreadPools
Fet a fluent-style pool builder.
getPoolBuilder(ThreadPoolNames) - Method in class org.apache.accumulo.core.util.threads.ThreadPools
Fet a fluent-style pool builder.
getPoolNameForTable(String) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
Matches table name against pool names, returns matching pool name or DEFAULT_POOL.
getPoolNamesForHost(TabletServerId) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
Matches host against the regexes and returns the matching pool names
getPoolNameToRegexPattern() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getPort() - Method in interface org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost
 
getPort() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
getPort() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletServerId
 
getPort() - Method in class org.apache.accumulo.core.util.HostAndPort
Get the current port number, failing if no port is defined.
getPort(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.PORT, interpreting the value properly (as an integer within the range of non-privileged ports).
getPortOrDefault(int) - Method in class org.apache.accumulo.core.util.HostAndPort
Returns the current port number, with a default if no port is defined.
getPortStream(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
getPos() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
getPos() - Method in class org.apache.accumulo.core.file.streams.RateLimitedInputStream
 
getPos() - Method in class org.apache.accumulo.core.file.streams.SeekableDataInputStream
 
getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
getPositionAndReset() - Method in class org.apache.accumulo.core.iterators.YieldCallback
Called by the client to get the yield position used as the start key (non-inclusive) of the range in a subsequent seek call when the iterator is rebuilt.
getPrefix(Properties, String) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
getPrevEndRow() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Tablet
 
getPrevEndRow() - Method in interface org.apache.accumulo.core.data.TabletId
 
getPrevEndRow() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
getPrevEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
getPrevEndRow() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getPrevKey() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
getPrincipal() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getPrincipal() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
The identity of the user to which this token belongs to according to Kerberos
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getPrincipal() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.Credentials
Gets the principal.
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The principal of the logged in user for SASL
getPrincipal() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getPrincipal() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getPrincipal(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
Gets the user name from the configuration.
getPrincipal(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Gets the user name from the configuration.
getPrincipal(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
Gets the principal from the configuration.
getPrincipal(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Gets the user name from the configuration.
getPrincipal(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
Gets the user name from the configuration.
getPrintableTableInfoFromId(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getPrintableTableInfoFromId(TableId) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
getPrintableTableInfoFromName(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getPrintableTableInfoFromName(String) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
getPrioritizerClass() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor.Config
 
getPrioritizerOptions() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor.Config
 
getPriority() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get layer at which this iterator applies.
getPriority() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
getPriority() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
getPriority() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getPriority() - Method in interface org.apache.accumulo.core.spi.common.IteratorConfiguration
 
getPriority() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionJob
 
getPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
getPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
getPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getPriority() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
getProgress() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
getProgress() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
Deprecated.
 
getProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getProgress(ByteSequence, ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getProgress(ByteSequence, ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.SplitUtils
Deprecated.
 
getProgress(Key) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getProgress(Key) - Method in class org.apache.accumulo.core.clientImpl.mapreduce.BatchInputSplit
Deprecated.
Save progress on each call to this function, implied by value of currentKey, and return average ranges in the split
getPropagateDeletes() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getProperties() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Retrieves the complete set of currently configured table properties to be applied to a table when this configuration object is used.
getProperties() - Method in interface org.apache.accumulo.core.client.security.tokens.AuthenticationToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getProperties() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.mapreduce.DelegationTokenStub
Deprecated.
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
getProperties() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getProperties(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Gets a merged view of the properties of a namespace with its parent configuration.
getProperties(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets a merged view of the properties of a table with its parent configuration.
getProperties(String, CacheType) - Method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getProperties(String, CacheType) - Method in interface org.apache.accumulo.core.spi.cache.BlockCacheManager.Configuration
This method provides a way for a cache implementation to access arbitrary configuration set by a user.
getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Returns property key/value pairs in this configuration.
getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getProperties(Map<String, String>, Predicate<String>, boolean) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getPropertiesPath() - Method in class org.apache.accumulo.core.cli.ConfigOpts
 
getPropertiesSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
getPropertiesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getPropertiesToExclude() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
The source table properties are copied, this allows reverting to system defaults for some of those properties.
getPropertiesToExclude() - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
getPropertiesToSet() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
The source table properties are copied.
getPropertiesToSet() - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getProperty() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
getProperty(IteratorUtil.IteratorScope) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
Fetch the correct configuration key prefix for the given scope.
getPropertyByKey(String) - Static method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
Deprecated.
 
getPropertyByKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
Gets a Property instance with the given key.
getPropertyId() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
The propertyId is used when creating table properties for a summarizer.
getProtocol(TTransport) - Method in class org.apache.accumulo.core.rpc.TraceProtocolFactory
 
getQualifier() - Method in class org.apache.accumulo.core.data.Condition
Gets the column qualifier of this condition.
getQuality() - Method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
 
getQualityOfProtection() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The quality of protection used with SASL.
getQueryByteRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getQueryByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getQueryByteRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getQueryRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getQueryRate() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getQueryRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getQueryRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getQueryRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getQueryRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getQueue() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
getQueued() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getQueued() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor
 
getQueueName() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getQueueName() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getQueueName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
getQueueName() - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
getQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getRange() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getRange() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getRange() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getRange() - Method in interface org.apache.accumulo.core.client.Scanner
Returns the range of keys to scan over.
getRange() - Method in class org.apache.accumulo.core.clientImpl.mapreduce.BatchInputSplit
Deprecated.
 
getRange() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
getRange() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getRange() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ExternalCompactionSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.OldScanServerFileReferenceSection
Deprecated.
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ProblemSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ScanServerFileReferenceSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
getRange() - Method in class org.apache.accumulo.core.schema.Section
 
getRange() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getRange(UUID) - Static method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
Returns the correctly formatted range for a unique uuid
getRange(TableId) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
getRangeLength(Range) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.SplitUtils
Deprecated.
 
getRanges() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Deprecated.
Returns the ranges to be queried in the configuration
getRanges() - Method in class org.apache.accumulo.core.clientImpl.mapreduce.BatchInputSplit
Deprecated.
 
getRanges(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Gets the ranges to scan over from a job.
getRanges(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
Deprecated.
Gets the ranges to scan over from a job.
getRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
Deprecated.
Gets the ranges to scan over from a job.
getRangeType() - Method in class org.apache.accumulo.core.data.LoadPlan.Destination
 
getRate() - Method in class org.apache.accumulo.core.util.ratelimit.GuavaRateLimiter
 
getRate() - Method in class org.apache.accumulo.core.util.ratelimit.NullRateLimiter
 
getRate() - Method in interface org.apache.accumulo.core.util.ratelimit.RateLimiter
Get current QPS of the rate limiter, with a non-positive rate indicating no limit.
getRateLimit(String) - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
getRateLimiter() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getRateLimits() - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
getRatio() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Get the uncompressed size of the block.
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
Get the raw size of the block.
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getReadaheadThreshold() - Method in interface org.apache.accumulo.core.client.Scanner
The number of batches of Key/Value pairs returned before the Scanner will begin to prefetch the next batch
getReadaheadThreshold() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getReason() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getReason() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getReason() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
 
getReason() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
 
getReason() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloInputFormat
Deprecated.
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloMultiTableInputFormat
Deprecated.
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloRowInputFormat
Deprecated.
 
getRecords() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getRecords() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getRecordsInMemory() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getRecordsInMemory() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
Deprecated.
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
Deprecated.
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
 
getRecs() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getRecsInMemory() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getRegistry() - Method in interface org.apache.accumulo.core.metrics.MetricsInfo
 
getRemainder() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
getRemaining() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
getRemoteIdentifier() - Method in class org.apache.accumulo.core.replication.ReplicationTarget
Deprecated.
 
getRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
getRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
 
getRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
 
getReplacementName(String, BiConsumer<Logger, String>) - Static method in class org.apache.accumulo.core.conf.DeprecatedPropertyUtil
Checks if propertyName is a deprecated property name and return its replacement name, if one is available, or the original name if no replacement is available.
getReplicationSources() - Method in class org.apache.accumulo.core.data.Mutation
Deprecated.
The feature pertaining to this method was deprecated in 2.1.0, but this method was overlooked when annotating the code. It is being marked as deprecated in 2.1.1 in order to correct that oversight, and will be removed in 3.0.0 with the rest of the code pertaining to this feature.
getRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
getRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
getRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
getRequestedExecutors() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getRequestedExternalExecutors() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getRequestTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getReservationCount() - Static method in class org.apache.accumulo.core.singletons.SingletonManager
 
getResponseTime() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getResponseTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getResponseTime() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.authenticate_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.authenticateUser_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.bulkImportFiles_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.changeAuthorizations_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkClass_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkTableClass_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.createLocalUser_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.dropLocalUser_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getDiskUsage_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getInstanceId_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getSystemProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedNamespaceProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedSystemProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedTableProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getZooKeepers_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantTablePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasTablePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.isActive_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.listLocalUsers_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.ping_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeTablePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.fails_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.success_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.throwsError_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.cancel_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.compactionCompleted_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.compactionFailed_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompactionJob_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompletedCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getRunningCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.updateCompactionStatus_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.cancel_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getActiveCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompaction_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompactionId_call
 
getResult() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
getResult() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
getResult() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.beginFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.cancelFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.executeFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.finishFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.waitForFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.drainReplicationTable_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getActiveTservers_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getDelegationToken_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getManagerStats_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.initiateFlush_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifyNamespaceProperties_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifySystemProperties_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifyTableProperties_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeNamespaceProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeSystemProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeTableProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.reportSplitExtent_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.reportTabletStatus_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setManagerGoalState_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setNamespaceProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setSystemProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setTableProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.shutdown_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.shutdownTabletServer_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.waitForBalance_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.waitForFlush_call
 
getResult() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient.getServicerAddress_call
 
getResult() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient.replicateKeyValues_call
 
getResult() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient.replicateLog_call
 
getResult() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerAttempt
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.applyUpdates_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.bulkImport_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.cancelUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.chop_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compact_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compactionJobFailed_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compactionJobFinished_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.conditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.contiuneGetSummaries_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.fastHalt_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flush_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flushTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveLogs_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getCompactionQueueInfo_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getHistoricalStats_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletServerStatus_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletStats_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.halt_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.invalidateConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.loadFiles_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.loadTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.removeLogs_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.reserveCompactionJob_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.splitTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startGetSummaries_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startGetSummariesForPartition_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startGetSummariesFromFiles_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.unloadTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.update_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.closeMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.closeScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.continueMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.continueScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.getActiveScans_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.startMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncClient.startScan_call
 
getResult(I, ClientService.authenticate_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticate
 
getResult(I, ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticateUser
 
getResult(I, ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.bulkImportFiles
 
getResult(I, ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeAuthorizations
 
getResult(I, ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeLocalUserPassword
 
getResult(I, ClientService.checkClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkClass
 
getResult(I, ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkNamespaceClass
 
getResult(I, ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkTableClass
 
getResult(I, ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.createLocalUser
 
getResult(I, ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.dropLocalUser
 
getResult(I, ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getConfiguration
 
getResult(I, ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getDiskUsage
 
getResult(I, ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getInstanceId
 
getResult(I, ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceConfiguration
 
getResult(I, ClientService.getNamespaceProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceProperties
 
getResult(I, ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getRootTabletLocation
 
getResult(I, ClientService.getSystemProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getSystemProperties
 
getResult(I, ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableConfiguration
 
getResult(I, ClientService.getTableProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableProperties
 
getResult(I, ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getUserAuthorizations
 
getResult(I, ClientService.getVersionedNamespaceProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedNamespaceProperties
 
getResult(I, ClientService.getVersionedSystemProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedSystemProperties
 
getResult(I, ClientService.getVersionedTableProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedTableProperties
 
getResult(I, ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getZooKeepers
 
getResult(I, ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantNamespacePermission
 
getResult(I, ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantSystemPermission
 
getResult(I, ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantTablePermission
 
getResult(I, ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasNamespacePermission
 
getResult(I, ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasSystemPermission
 
getResult(I, ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasTablePermission
 
getResult(I, ClientService.isActive_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.isActive
 
getResult(I, ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.listLocalUsers
 
getResult(I, ClientService.ping_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.ping
 
getResult(I, ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeNamespacePermission
 
getResult(I, ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeSystemPermission
 
getResult(I, ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeTablePermission
 
getResult(I, ThriftTest.fails_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.fails
 
getResult(I, ThriftTest.success_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.success
 
getResult(I, ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.throwsError
 
getResult(I, CompactionCoordinatorService.cancel_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.cancel
 
getResult(I, CompactionCoordinatorService.compactionCompleted_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionCompleted
 
getResult(I, CompactionCoordinatorService.compactionFailed_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionFailed
 
getResult(I, CompactionCoordinatorService.getCompactionJob_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompactionJob
 
getResult(I, CompactionCoordinatorService.getCompletedCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompletedCompactions
 
getResult(I, CompactionCoordinatorService.getRunningCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getRunningCompactions
 
getResult(I, CompactionCoordinatorService.updateCompactionStatus_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.updateCompactionStatus
 
getResult(I, CompactorService.cancel_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.cancel
 
getResult(I, CompactorService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getActiveCompactions
 
getResult(I, CompactorService.getRunningCompaction_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompaction
 
getResult(I, CompactorService.getRunningCompactionId_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompactionId
 
getResult(I, GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
getResult(I, FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.beginFateOperation
 
getResult(I, FateService.cancelFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.cancelFateOperation
 
getResult(I, FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.executeFateOperation
 
getResult(I, FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.finishFateOperation
 
getResult(I, FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.waitForFateOperation
 
getResult(I, ManagerClientService.drainReplicationTable_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.drainReplicationTable
 
getResult(I, ManagerClientService.getActiveTservers_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getActiveTservers
 
getResult(I, ManagerClientService.getDelegationToken_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getDelegationToken
 
getResult(I, ManagerClientService.getManagerStats_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getManagerStats
 
getResult(I, ManagerClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.initiateFlush
 
getResult(I, ManagerClientService.modifyNamespaceProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyNamespaceProperties
 
getResult(I, ManagerClientService.modifySystemProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifySystemProperties
 
getResult(I, ManagerClientService.modifyTableProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyTableProperties
 
getResult(I, ManagerClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeNamespaceProperty
 
getResult(I, ManagerClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeSystemProperty
 
getResult(I, ManagerClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeTableProperty
 
getResult(I, ManagerClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportSplitExtent
 
getResult(I, ManagerClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportTabletStatus
 
getResult(I, ManagerClientService.setManagerGoalState_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setManagerGoalState
 
getResult(I, ManagerClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setNamespaceProperty
 
getResult(I, ManagerClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setSystemProperty
 
getResult(I, ManagerClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setTableProperty
 
getResult(I, ManagerClientService.shutdown_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdown
 
getResult(I, ManagerClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdownTabletServer
 
getResult(I, ManagerClientService.waitForBalance_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForBalance
 
getResult(I, ManagerClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForFlush
 
getResult(I, ReplicationCoordinator.getServicerAddress_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Processor.getServicerAddress
 
getResult(I, ReplicationServicer.replicateKeyValues_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateKeyValues
 
getResult(I, ReplicationServicer.replicateLog_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateLog
 
getResult(I, TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
 
getResult(I, TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
 
getResult(I, TabletClientService.cancelUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.cancelUpdate
 
getResult(I, TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
 
getResult(I, TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
 
getResult(I, TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
 
getResult(I, TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
 
getResult(I, TabletClientService.compactionJobFailed_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compactionJobFailed
 
getResult(I, TabletClientService.compactionJobFinished_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compactionJobFinished
 
getResult(I, TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
 
getResult(I, TabletClientService.contiuneGetSummaries_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.contiuneGetSummaries
 
getResult(I, TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
 
getResult(I, TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
 
getResult(I, TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
 
getResult(I, TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
 
getResult(I, TabletClientService.getActiveLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveLogs
 
getResult(I, TabletClientService.getCompactionQueueInfo_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getCompactionQueueInfo
 
getResult(I, TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
 
getResult(I, TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
 
getResult(I, TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
 
getResult(I, TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
 
getResult(I, TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
 
getResult(I, TabletClientService.loadFiles_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadFiles
 
getResult(I, TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
 
getResult(I, TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
 
getResult(I, TabletClientService.reserveCompactionJob_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.reserveCompactionJob
 
getResult(I, TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
 
getResult(I, TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
 
getResult(I, TabletClientService.startGetSummaries_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startGetSummaries
 
getResult(I, TabletClientService.startGetSummariesForPartition_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startGetSummariesForPartition
 
getResult(I, TabletClientService.startGetSummariesFromFiles_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startGetSummariesFromFiles
 
getResult(I, TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
 
getResult(I, TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
 
getResult(I, TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
 
getResult(I, TabletScanClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.closeMultiScan
 
getResult(I, TabletScanClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.closeScan
 
getResult(I, TabletScanClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.continueMultiScan
 
getResult(I, TabletScanClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.continueScan
 
getResult(I, TabletScanClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.getActiveScans
 
getResult(I, TabletScanClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.startMultiScan
 
getResult(I, TabletScanClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.Processor.startScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticateUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.bulkImportFiles
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkTableClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.createLocalUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getInstanceId
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getSystemProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedNamespaceProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedSystemProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedTableProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.isActive
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.ping
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.fails
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.success
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.throwsError
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.cancel
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionCompleted
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionFailed
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompactionJob
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getRunningCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.updateCompactionStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.cancel
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getActiveCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompaction
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompactionId
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.beginFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.cancelFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.executeFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.finishFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.waitForFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.drainReplicationTable
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getActiveTservers
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getDelegationToken
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getManagerStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.initiateFlush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyNamespaceProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifySystemProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyTableProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeNamespaceProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeSystemProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeTableProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportSplitExtent
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportTabletStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setManagerGoalState
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setNamespaceProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setSystemProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setTableProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdown
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdownTabletServer
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForBalance
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForFlush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor.getServicerAddress
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateKeyValues
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateLog
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.cancelUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compactionJobFailed
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compactionJobFinished
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.contiuneGetSummaries
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveLogs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getCompactionQueueInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadFiles
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.reserveCompactionJob
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startGetSummaries
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startGetSummariesForPartition
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startGetSummariesFromFiles
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.closeMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.closeScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.continueMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.continueScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.getActiveScans
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.startMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.AsyncProcessor.startScan
 
getResults() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getResults() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
getResultsIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getResultsIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
getResultsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getResultsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
getRetryFactory() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getReturn() - Method in interface org.apache.accumulo.core.fate.Repo
 
getReturn(long) - Method in class org.apache.accumulo.core.fate.Fate
 
getRoot(InstanceId) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
 
getRootMetadata(String, ZooCache) - Static method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata
 
getRootTabletLocation() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
getRootTabletLocation() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getRootTabletLocation
 
getRootTabletLocation() - Method in interface org.apache.accumulo.core.client.Instance
Deprecated.
Returns the location of the tablet server that is serving the root tablet.
getRootTabletLocation() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
Deprecated.
 
getRootTabletLocation() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns the location of the tablet server that is serving the root tablet.
getRootTabletLocation() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getRootTabletLocation() - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getRootTabletLocation(ClientContext) - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
getRootTabletLocation(AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getRootTabletLocation(AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getRootTabletLocation_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
getRootTabletLocation_args(ClientService.getRootTabletLocation_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
Performs a deep copy on other.
getRootTabletLocation_call(AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
 
getRootTabletLocation_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
getRootTabletLocation_result(String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
getRootTabletLocation_result(ClientService.getRootTabletLocation_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
Performs a deep copy on other.
getRow() - Method in class org.apache.accumulo.core.data.Key
Gets the row ID as a Text object.
getRow() - Method in class org.apache.accumulo.core.data.Mutation
Gets the row ID for this mutation.
getRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getRow() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getRow() - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
 
getRow(Text) - Method in class org.apache.accumulo.core.data.Key
Writes the row ID into the given Text.
getRowData() - Method in class org.apache.accumulo.core.data.Key
Returns the row ID as a byte sequence.
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ExternalCompactionSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.OldScanServerFileReferenceSection
Deprecated.
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ProblemSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ScanServerFileReferenceSection
 
getRowPrefix() - Method in class org.apache.accumulo.core.schema.Section
 
getRunning() - Method in class org.apache.accumulo.core.master.thrift.Compacting
 
getRunningCompaction() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompaction
 
getRunningCompaction() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompaction
 
getRunningCompaction(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
getRunningCompaction(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.Iface
 
getRunningCompaction(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionJob>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient
 
getRunningCompaction(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionJob>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncIface
 
getRunningCompaction(HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
Get the compaction currently running on the Compactor
getRunningCompaction_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getRunningCompaction_args(CompactorService.getRunningCompaction_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
Performs a deep copy on other.
getRunningCompaction_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getRunningCompaction_call(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionJob>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompaction_call
 
getRunningCompaction_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getRunningCompaction_result(CompactorService.getRunningCompaction_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
Performs a deep copy on other.
getRunningCompaction_result(TExternalCompactionJob, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getRunningCompactionId() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompactionId
 
getRunningCompactionId() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompactionId
 
getRunningCompactionId(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
getRunningCompactionId(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.Iface
 
getRunningCompactionId(TInfo, TCredentials, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient
 
getRunningCompactionId(TInfo, TCredentials, AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncIface
 
getRunningCompactionId_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getRunningCompactionId_args(CompactorService.getRunningCompactionId_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
Performs a deep copy on other.
getRunningCompactionId_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getRunningCompactionId_call(TInfo, TCredentials, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompactionId_call
 
getRunningCompactionId_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getRunningCompactionId_result(String, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getRunningCompactionId_result(CompactorService.getRunningCompactionId_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
Performs a deep copy on other.
getRunningCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getRunningCompactions
 
getRunningCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getRunningCompactions
 
getRunningCompactions() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getRunningCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
getRunningCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
getRunningCompactions(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
getRunningCompactions(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
getRunningCompactions_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getRunningCompactions_args(CompactionCoordinatorService.getRunningCompactions_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
Performs a deep copy on other.
getRunningCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getRunningCompactions_call(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getRunningCompactions_call
 
getRunningCompactions_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
getRunningCompactions_result(CompactionCoordinatorService.getRunningCompactions_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
Performs a deep copy on other.
getRunningCompactions_result(TExternalCompactionList) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
getRuntime() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
 
getRunTimeStats() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
Returns timing statistics about running and gathering a batches of data.
getSalt(int) - Method in class org.apache.accumulo.core.spi.scan.ConfigurableScanServerSelector.Profile
 
getSample(CompactableFile, SamplerConfiguration) - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getSample(SamplerConfigurationImpl) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getSamplerClassName() - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
getSamplerConfig() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getSamplerConfig() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getSamplerConfiguration() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
Deprecated.
 
getSamplerConfiguration() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getSamplerConfiguration() - Method in interface org.apache.accumulo.core.client.ScannerBase
 
getSamplerConfiguration() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getSamplerConfiguration() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
getSamplerConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Reads the sampling configuration properties for a table.
getSamplerConfiguration(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getSaslParams() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve SASL configuration to initiate an RPC connection to a server
getSaslParams() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
getSaslProperties() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
getScanAuthorizations(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator
Gets the authorizations to set for the scans from the configuration.
getScanAuthorizations(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Gets the authorizations to set for the scans from the configuration.
getScanAuthorizations(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Gets the authorizations to set for the scans from the configuration.
getScanExecutors() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.DispatchParameters
 
getScanExecutors(boolean) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getScanid() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getScanid() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getScanId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getScanID() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
getScanID() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
getScanInfo() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.DispatchParameters
 
getScanner(AccumuloClient) - Static method in class org.apache.accumulo.core.replication.ReplicationTable
Deprecated.
 
getScannerIterator() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
getScanRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getScanRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getScanRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getScans() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getScans() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getScanServer(TabletId) - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelections
 
getScanServerFileReferences() - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Get ScanServer references to Tablet files
getScanServers() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Returns the locations of the active scan servers
getScanServers() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getScanServers() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getScanServers() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.InitParameters
 
getScanServerSelector() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getScanType() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
 
getScope() - Method in class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
 
getScope() - Method in interface org.apache.accumulo.core.spi.crypto.CryptoEnvironment
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getSec() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
getSecond() - Method in class org.apache.accumulo.core.util.Pair
 
getSecret() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getSecs(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
getSecurityErrorCode() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getSecurityErrorCodes() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getSeen() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getSelector() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getSerializedFormat() - Method in class org.apache.accumulo.core.data.Mutation
Gets the serialization format used to (de)serialize this mutation.
getSerialVersion() - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
getServ() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
getServer() - Method in exception org.apache.accumulo.core.clientImpl.AccumuloServerException
 
getServer() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
getServer() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
getServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getServer() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerAttempt
 
getServerInstance() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getServerLockUUID() - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
getServerName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getServerName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getServerProtocols() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getServersShuttingDown() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getServersShuttingDownIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getServersShuttingDownSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getServerThreadPools() - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
 
getService() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatch
 
getService(CryptoEnvironment, Map<String, String>) - Method in interface org.apache.accumulo.core.spi.crypto.CryptoServiceFactory
Return the appropriate CryptoService.
getService(CryptoEnvironment, Map<String, String>) - Method in class org.apache.accumulo.core.spi.crypto.GenericCryptoServiceFactory
 
getService(CryptoEnvironment, Map<String, String>) - Method in class org.apache.accumulo.core.spi.crypto.NoCryptoServiceFactory
 
getService(CryptoEnvironment, Map<String, String>) - Method in class org.apache.accumulo.core.spi.crypto.PerTableCryptoServiceFactory
 
getServicedTableId() - Method in class org.apache.accumulo.core.metadata.MetadataServicer
 
getServiceEnv() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Deprecated.
since 2.1.0. This method was using a non public API type. Use IteratorEnvironment.getPluginEnv() instead because it has better stability guarantees.
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.DispatchParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.InitParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.metrics.MeterRegistryFactory.InitParameters
Optional extension point to pass additional information though the ServiceEnvironment.
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.DispatchParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.InitParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.scan.ScanPrioritizer.CreateParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.InitParameters
 
getServiceEnvironment() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.InitParameters
 
getServiceEnvironment() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getServiceEnvironment() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getServiceForClient(CryptoEnvironment.Scope, Map<String, String>) - Static method in class org.apache.accumulo.core.crypto.CryptoFactoryLoader
Returns a CryptoService configured for the scope using the properties.
getServiceForClientWithTable(Map<String, String>, Map<String, String>, TableId) - Static method in class org.apache.accumulo.core.crypto.CryptoFactoryLoader
For use by client code, in a Table context.
getServiceForServer(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.crypto.CryptoFactoryLoader
For use by server utilities not associated with a table.
getServiceName() - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
The service name used to identify the Token
getServiceName() - Method in class org.apache.accumulo.core.clientImpl.mapreduce.DelegationTokenStub
Deprecated.
 
getServiceName() - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getServicerAddress() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor.getServicerAddress
 
getServicerAddress() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Processor.getServicerAddress
 
getServicerAddress(String, TCredentials) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client
 
getServicerAddress(String, TCredentials) - Method in interface org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Iface
 
getServicerAddress(String, TCredentials, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient
 
getServicerAddress(String, TCredentials, AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncIface
 
getServicerAddress_args() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
getServicerAddress_args(String, TCredentials) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
 
getServicerAddress_args(ReplicationCoordinator.getServicerAddress_args) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
Performs a deep copy on other.
getServicerAddress_call(String, TCredentials, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient.getServicerAddress_call
 
getServicerAddress_result() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
getServicerAddress_result(String, ReplicationCoordinatorException) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
getServicerAddress_result(ReplicationCoordinator.getServicerAddress_result) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
Performs a deep copy on other.
getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
getSession() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
getSession() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getSession() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getSession() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletServerId
 
getSessionId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
getSessionId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getSessionId() - Method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
getSessionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
getSessionId(ZooCache, ServiceLock.ServiceLockPath) - Static method in class org.apache.accumulo.core.fate.zookeeper.ServiceLock
 
getSessionTimeout() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
Returns the requested ZooKeeper client session timeout.
getShownLength() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
 
getSimulationMode(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.OutputConfigurator
Determines whether this feature is enabled.
getSimulationMode(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
Determines whether this feature is enabled.
getSimulationMode(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
Determines whether this feature is enabled.
getSince() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getSingleFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getSiteConfiguration() - Method in class org.apache.accumulo.core.cli.ConfigOpts
 
getSiteConfiguration() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Retrieve the site configuration (that is set in the server configuration file).
getSiteConfiguration() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getSize() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
getSize() - Method in class org.apache.accumulo.core.data.Key
getSize() - Method in class org.apache.accumulo.core.data.Value
Gets the size of this value.
getSize() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getSizeIterator(AccumuloClient, String, Text, Text) - Method in class org.apache.accumulo.core.util.Merge
 
getSource() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getSources() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getSourcesIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getSourcesSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getSourceTableId() - Method in class org.apache.accumulo.core.replication.ReplicationTarget
Deprecated.
 
getSplit() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getSplitCreationTime() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getSplitCreationTime() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getSplitRatio() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getSplits() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Return Collection of split values.
getSplits() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getSplits(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Deprecated.
since 1.5.0; use TableOperations.listSplits(String) instead.
getSplits(String, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Deprecated.
since 1.5.0; use TableOperations.listSplits(String, int) instead.
getSplits(JobConf, int) - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
Deprecated.
Gets the splits of the tables that have been set on the job by reading the metadata table for the specified ranges.
getSplits(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
Gets the splits of the tables that have been set on the job by reading the metadata table for the specified ranges.
getSsbe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
getSsbe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
getSsbe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
getSsbe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
getSsiList() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getSsiList() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getSsio() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getSsio() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getSslParams() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
getStack(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
getStack(long) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Get all operations on a transactions stack.
getStack(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
getStart() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
getStarted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getStartKey() - Method in class org.apache.accumulo.core.data.Range
Gets the start key, or null if the start is negative infinity.
getStartPos() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
 
getStartRow() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getStartRow() - Method in class org.apache.accumulo.core.data.LoadPlan.Destination
 
getStartRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
getStartRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getStartRow() - Method in class org.apache.accumulo.core.summary.Gatherer.RowRange
 
getStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getStartTime() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
getState() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getState() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getState() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
getState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getState() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
 
getState() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getState(Set<TServerInstance>) - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getStatistics() - Method in class org.apache.accumulo.core.client.summary.Summary
 
getStats() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get counter statistics for this cache.
getStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getStats() - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getStats() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Get the statistics of this cache.
getStats() - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
Finalize the aggregation and return the result.
getStats() - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
 
getStats() - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
 
getStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
getStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
getStatus() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
If this method throws an exception, then its possible the mutation is still being actively processed.
getStatus() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getStatus() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
getStatus() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getStatus() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
getStatus() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getStatus(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
getStatus(long) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Get the state of a given transaction.
getStatus(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
getStatus(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getStatus(String, Watcher) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getStatus(ReadOnlyTStore<T>, ZooReader, ServiceLock.ServiceLockPath, Set<Long>, EnumSet<ReadOnlyTStore.TStatus>) - Method in class org.apache.accumulo.core.fate.AdminUtil
Get the FATE transaction status and lock information stored in zookeeper, optionally filtered by transaction id and filter status.
getStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
getStatus(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.Iface
 
getStatus(TInfo, TCredentials, AsyncMethodCallback<GCStatus>) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient
 
getStatus(TInfo, TCredentials, AsyncMethodCallback<GCStatus>) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncIface
 
getStatus_args() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getStatus_args(GCMonitorService.getStatus_args) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
Performs a deep copy on other.
getStatus_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getStatus_call(TInfo, TCredentials, AsyncMethodCallback<GCStatus>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
 
getStatus_result() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getStatus_result(GCMonitorService.getStatus_result) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
Performs a deep copy on other.
getStatus_result(GCStatus, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getStop() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
getStoredTabletFile() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getString(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
Deprecated.
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
 
getSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
 
getSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result
 
getSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getSummaries() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getSummaries() - Method in class org.apache.accumulo.core.summary.SummaryCollection
 
getSummaries(Collection<CompactableFile>, Predicate<SummarizerConfiguration>) - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getSummaries(List<Gatherer.RowRange>) - Method in class org.apache.accumulo.core.summary.SummaryReader
 
getSummariesIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getSummariesSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getSummarizer(SummarizerConfiguration) - Method in class org.apache.accumulo.core.summary.SummarizerFactory
 
getSummarizerConfigs(Iterable<Map.Entry<String, String>>) - Static method in class org.apache.accumulo.core.summary.SummarizerConfigurationUtil
 
getSummarizerConfigs(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.summary.SummarizerConfigurationUtil
 
getSummarizerConfiguration() - Method in class org.apache.accumulo.core.client.summary.Summary
 
getSummarizerPattern() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getSummarizers() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getSummarizersIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getSummarizersSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getSummary() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getSummarySize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getSupportedAlgorithms() - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Compression
 
getSuspend() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getSymbols() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getSymbolsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getSymbolsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getSymbolTable() - Method in class org.apache.accumulo.core.clientImpl.CompressedIterators
 
getSyncs() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getSyncs() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getSyncs() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getSysPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getSystemConfiguration() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Retrieve the system-wide configuration.
getSystemConfiguration() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getSystemProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getSystemProperties
 
getSystemProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getSystemProperties
 
getSystemProperties(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getSystemProperties(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getSystemProperties(TInfo, TCredentials, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getSystemProperties(TInfo, TCredentials, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getSystemProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getSystemProperties_args(ClientService.getSystemProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
Performs a deep copy on other.
getSystemProperties_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getSystemProperties_call(TInfo, TCredentials, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getSystemProperties_call
 
getSystemProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSystemProperties_result(Map<String, String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSystemProperties_result(ClientService.getSystemProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
Performs a deep copy on other.
getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getTable() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
since 1.6.1, use getTableName() instead.
getTable() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getTable() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getTable() - Method in interface org.apache.accumulo.core.data.TabletId
 
getTable() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
getTable() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
getTable() - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment
 
getTableConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
getTableConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableConfiguration
 
getTableConfiguration() - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
getTableConfiguration() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getTableConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getTableConfiguration(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getTableConfiguration(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getTableConfiguration(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getTableConfiguration_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getTableConfiguration_args(ClientService.getTableConfiguration_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
Performs a deep copy on other.
getTableConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getTableConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableConfiguration_call
 
getTableConfiguration_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getTableConfiguration_result(Map<String, String>, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getTableConfiguration_result(ClientService.getTableConfiguration_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
Performs a deep copy on other.
getTableCustom() - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Users can set arbitrary custom table properties in Accumulo using the prefix table.custom..
getTableCustom() - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getTableCustom(String) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
This method appends the prefix table.custom and gets the property.
getTableCustom(String) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getTableId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InitParameters
 
getTableId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InputParameters
 
getTableId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.InitParameters
 
getTableId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getTableId() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getTableId() - Method in exception org.apache.accumulo.core.client.TableDeletedException
 
getTableId() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getTableId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getTableId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getTableId() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getTableId() - Method in class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
 
getTableId() - Method in interface org.apache.accumulo.core.data.TabletId
Deprecated.
getTableId() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
Deprecated.
getTableId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getTableId() - Method in interface org.apache.accumulo.core.gc.Reference
Get the TableId of the reference.
getTableId() - Method in class org.apache.accumulo.core.gc.ReferenceFile
 
getTableId() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Return the table Id associated with this iterator.
getTableId() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getTableId() - Method in class org.apache.accumulo.core.metadata.TabletFile.FileParts
 
getTableId() - Method in class org.apache.accumulo.core.metadata.TabletFile
 
getTableId() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.InitParameters
 
getTableId() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getTableId() - Method in interface org.apache.accumulo.core.spi.crypto.CryptoEnvironment
If in the TABLE scope, get the tableId.
getTableId() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.InitParameters
 
getTableId() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getTableId(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableId(String) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Lookup table ID in ZK.
getTableId(Key) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
Extract the table ID from the colfam
getTableId(Key) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.StatusSection
Deprecated.
Extract the table ID from the key (inefficiently if called repeatedly)
getTableId(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
Deprecated.
Extract the table ID from the given key
getTableID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getTableIdMap() - Method in interface org.apache.accumulo.core.spi.balancer.BalancerEnvironment
Many Accumulo plugins are given table IDs as this is what Accumulo uses internally to identify tables.
getTableIds(ClientContext, NamespaceId) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
 
getTableIdToNameMap() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableInfo() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getTableMap() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getTableMap() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTableMap() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getTableMap() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getTableMap() - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Get the TableMap from the cache.
getTableMapSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTableMapSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
 
getTableName() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getTableName() - Method in exception org.apache.accumulo.core.client.TableNotFoundException
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getTableName() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getTableName(TableId) - Method in interface org.apache.accumulo.core.client.PluginEnvironment
Many Accumulo plugins are given table IDs as this is what Accumulo uses internally to identify tables.
getTableName(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableName(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
getTableName(TableId) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
getTableNames(ClientContext, NamespaceId) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
 
getTableNameToIdMap() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableProperties
 
getTableProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableProperties
 
getTableProperties(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets per-table properties of a table.
getTableProperties(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getTableProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getTableProperties(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getTableProperties(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getTableProperties(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getTableProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getTableProperties_args(ClientService.getTableProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
Performs a deep copy on other.
getTableProperties_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getTableProperties_call(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableProperties_call
 
getTableProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getTableProperties_result(Map<String, String>, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getTableProperties_result(ClientService.getTableProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
Performs a deep copy on other.
getTables() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
getTables() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getTables() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getTablesIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getTablesIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getTablesSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getTablesSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getTableState(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableState(TableId, boolean) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableState(TableId, boolean) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Get the current state of the table using the tableid.
getTablet() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getTablet() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getTablet() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getTablet() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getTablet() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Mapping
 
getTablet() - Method in interface org.apache.accumulo.core.data.constraints.Constraint.Environment
Gets the tablet Id of the environment.
getTablet() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getTablet() - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
getTabletCount() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getTabletCount() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getTabletDir() - Method in class org.apache.accumulo.core.metadata.TabletFile.FileParts
 
getTabletDir() - Method in class org.apache.accumulo.core.metadata.TabletFile
 
getTabletId() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getTabletId() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getTabletLocation(TabletId) - Method in interface org.apache.accumulo.core.client.admin.Locations
For any TabletId known to this object, the method will return the tablet server location for that tablet.
getTabletLocations(SortedMap<KeyExtent, String>) - Method in class org.apache.accumulo.core.metadata.MetadataServicer
Populate the provided data structure with the known tablets for the table being serviced
getTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
 
getTablets() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.SelectorParameters
 
getTabletServer() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
 
getTabletServer() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
getTabletServerConnection(ClientContext, boolean) - Method in class org.apache.accumulo.core.rpc.clients.ClientServiceThriftClient
 
getTabletServerConnection(ClientContext, boolean) - Method in class org.apache.accumulo.core.rpc.clients.TabletServerThriftClient
 
getTabletServerConnection(ClientContext, boolean) - Method in interface org.apache.accumulo.core.rpc.clients.TServerClient
 
getTabletServerConnection(Logger, ThriftClientTypes<C>, ClientContext, boolean, AtomicBoolean) - Method in interface org.apache.accumulo.core.rpc.clients.TServerClient
 
getTabletServers() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the currently active tablet servers participating in the accumulo instance
getTabletServers() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getTabletServerStatus() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
 
getTabletServerStatus() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
 
getTabletServerStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getTabletServerStatus(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getTabletServerStatus(TInfo, TCredentials, AsyncMethodCallback<TabletServerStatus>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getTabletServerStatus(TInfo, TCredentials, AsyncMethodCallback<TabletServerStatus>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getTabletServerStatus_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
getTabletServerStatus_args(TabletClientService.getTabletServerStatus_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
Performs a deep copy on other.
getTabletServerStatus_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
getTabletServerStatus_call(TInfo, TCredentials, AsyncMethodCallback<TabletServerStatus>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletServerStatus_call
 
getTabletServerStatus_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
getTabletServerStatus_result(TabletServerStatus, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
 
getTabletServerStatus_result(TabletClientService.getTabletServerStatus_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
Performs a deep copy on other.
getTabletState(Set<TServerInstance>) - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getTabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
 
getTabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
 
getTabletStats(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
 
getTabletStats(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
 
getTabletStats(TInfo, TCredentials, String, AsyncMethodCallback<List<TabletStats>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
 
getTabletStats(TInfo, TCredentials, String, AsyncMethodCallback<List<TabletStats>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
 
getTabletStats_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getTabletStats_args(TabletClientService.getTabletStats_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
Performs a deep copy on other.
getTabletStats_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getTabletStats_call(TInfo, TCredentials, String, AsyncMethodCallback<List<TabletStats>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletStats_call
 
getTabletStats_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getTabletStats_result(List<TabletStats>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
 
getTabletStats_result(TabletClientService.getTabletStats_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
Performs a deep copy on other.
getTarget(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.WorkSection
Deprecated.
 
getTblNspcPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getTblPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getTerm(byte[]) - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTerm(Key) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
getTerm(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTermEnd() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTermStart() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTermString() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
getTfino() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.TNextCompactionJob._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.MapFileInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyValue._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.DeadServer._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.RecoveryException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.WalEdits._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ScanServerBusyException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
 
getThriftIdentifier() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getTid() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getTid() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
getTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
getTime() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getTime() - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
getTime() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getTimeClosed(Key) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
Deprecated.
 
getTimeClosed(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
Deprecated.
 
getTimeCreated() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getTimeCreatedFormatted() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getTimedOutSevers() - Method in exception org.apache.accumulo.core.client.TimedOutException
 
getTimeInMillis(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Interprets a string specifying a time duration.
getTimeInMillis(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getTimeInMillis(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.TIMEDURATION, interpreting the value properly.
getTimeout() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getTimeout(TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the setting for how long a scanner will automatically retry when a failure occurs.
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getTimestamp() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getTimestamp() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Gets the timestamp for this update.
getTimestamp() - Method in class org.apache.accumulo.core.data.Condition
Gets the timestamp of this condition.
getTimestamp() - Method in class org.apache.accumulo.core.data.Key
Gets the timestamp.
getTimestamp() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getTimestamp() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getTimeType() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Retrieve the time type currently configured.
getTimeType(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Return the TimeType for the given table
getTimeType(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getTimeZone() - Method in class org.apache.accumulo.core.util.format.DateFormatSupplier
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getTinfo() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFailed_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compactionJobFinished_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.contiuneGetSummaries_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getCompactionQueueInfo_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadFiles_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesForPartition_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummariesFromFiles_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.closeScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.getActiveScans_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args
 
getTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
getTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.drainReplicationTable_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
getToAuth() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
getToe() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getToken() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getToken() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
Deprecated.
 
getToken() - Method in class org.apache.accumulo.core.clientImpl.Credentials
Gets the authentication token.
getToken() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
getToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
getToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
getTokenClass(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
Deprecated.
getTokenClass(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
Deprecated.
getTokenClass(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
Deprecated.
getTokenClassName() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getTokenFromFile(Class<?>, Configuration, String, String) - Static method in class org.apache.accumulo.core.clientImpl.mapreduce.lib.ConfiguratorBase
Reads from the token file in distributed cache.
getTokenLifetime(TimeUnit) - Method in class org.apache.accumulo.core.client.admin.DelegationTokenConfig
The current token lifetime.
getTooLong() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getTooMany() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getTop() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.bulkImportFiles_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
getTope() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startGetSummaries_result
 
getTopKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getTopKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.Combiner
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.DevNull
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
getTopKey() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Returns top key.
getTopKey() - Method in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getTopValue() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.Combiner
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.DevNull
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
getTopValue() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Returns top value.
getTopValue() - Method in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.MapFileIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
getTotal() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getTotalFiles() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getTotalFiles() - Method in class org.apache.accumulo.core.summary.SummaryCollection
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getTransactionInfo(long, Fate.TxInfo) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
getTransactionInfo(long, Fate.TxInfo) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Retrieve transaction-specific information.
getTransactionInfo(long, Fate.TxInfo) - Method in class org.apache.accumulo.core.fate.ZooStore
 
getTransactions() - Method in class org.apache.accumulo.core.fate.AdminUtil.FateStatus
 
getTransactionStatus(ReadOnlyTStore<T>, Set<Long>, EnumSet<ReadOnlyTStore.TStatus>) - Method in class org.apache.accumulo.core.fate.AdminUtil
Returns a list of the FATE transactions, optionally filtered by transaction id and status.
getTransactionStatus(ReadOnlyTStore<T>, Set<Long>, EnumSet<ReadOnlyTStore.TStatus>, Map<Long, List<String>>, Map<Long, List<String>>) - Static method in class org.apache.accumulo.core.fate.AdminUtil
Returns fate status, possibly filtered
getTransport(ThriftClientTypes<?>, HostAndPort, long, ClientContext, boolean) - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportPool
 
getTransport(TTransport) - Method in class org.apache.accumulo.core.rpc.AccumuloTFramedTransportFactory
 
getTransport(TTransport) - Method in class org.apache.accumulo.core.rpc.UGIAssumingTransportFactory
 
getTransportPool() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTransportPoolMaxAgeMillis() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTrustStorePass() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getTrustStorePath() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getTrustStoreType() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getTs() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getTServerInfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTServerInfoIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTServerInfoSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTserverLock() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
getTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_result
 
getTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_result
 
getTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_result
 
getTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_result
 
getTSSLTransportParameters() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getTtl() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
getTxid() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getTxName() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getType() - Method in interface org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost
 
getType() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getType() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getType() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getType() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getType() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getType() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getType() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
getType() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getType() - Method in enum org.apache.accumulo.core.conf.Property
Gets the type of this property.
getType() - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
getType() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getType() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
 
getType(char) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataTime
Converts timetypes to data codes used in the table data implementation
getUid() - Method in class org.apache.accumulo.core.gc.GcCandidate
 
getUnassignedTablets() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getUniqueID() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getUnknownExceptions() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getUnnamedOptionDescriptions() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getUpdateCount() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Each time configuration changes, this counter should increase.
getUpdateCount() - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
getUpdateCount() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Returns a monotonically increasing count of the number of time the cache was updated.
getUpdatedLoadMapping(String, TableId, BulkSerialize.Input) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkSerialize
Read in both maps and change all the file names in the mapping to the new names.
getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
 
getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.cancelUpdate_args
 
getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
 
getUpdates() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getUpdates() - Method in class org.apache.accumulo.core.data.Mutation
Gets the modifications and deletions in this mutation.
getUpdates() - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
getUpdates() - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
 
getUpdatesSize() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getUri() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
getUri() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getUsage() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
getUsage() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getUser() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getUser() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getUser() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getUser() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getUser() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException