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 All Packages
All Classes All Packages
A
- ABSOLUTEPATH - 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.
- AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapreduce
-
Deprecated.
- 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 - org.apache.accumulo.core.client.ConditionalWriter.Status
-
conditions were met and mutation was written
- ACCEPTED - 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_PROPERTIES - 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
- 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
totabletServerId
. - 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
- 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
- addExecutorServiceMetrics(ExecutorService, String) - Static method in class org.apache.accumulo.core.metrics.MetricsUtil
- 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
- 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
- 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.
- 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
- 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 - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
- AGE - 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 - org.apache.accumulo.core.security.NamespacePermission
- ALTER_NAMESPACE - org.apache.accumulo.core.security.SystemPermission
- ALTER_TABLE - org.apache.accumulo.core.security.NamespacePermission
- ALTER_TABLE - org.apache.accumulo.core.security.SystemPermission
- ALTER_TABLE - org.apache.accumulo.core.security.TablePermission
- ALTER_USER - 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.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 - 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 - 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 - org.apache.accumulo.core.compaction.thrift.TCompactionState
- ASSIGNED - org.apache.accumulo.core.metadata.TabletState
- ASSIGNED_TO_DEAD_SERVER - org.apache.accumulo.core.metadata.TabletState
- ASSIGNING - 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
- 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
- auth(ZooKeeper, String, byte[]) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
- AUTH - org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
- AUTH_CONF - org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
- AUTH_INT - org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
- AUTH_OPT - Static variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
- AUTH_PRINCIPAL - org.apache.accumulo.core.conf.ClientProperty
- AUTH_TOKEN - org.apache.accumulo.core.conf.ClientProperty
- AUTH_TYPE - 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 - org.apache.accumulo.core.client.security.SecurityErrorCode
- AUTHENTICATOR_FAILED - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
- AUTHORIZATION_FAILURES - 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 - org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.ScanOpts
- AUTHORIZATIONS - org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
- AUTHORIZATIONS - org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- AUTHORIZATIONS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
- AUTHORIZATIONS - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
- AUTHORIZATIONS - 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 - org.apache.accumulo.core.client.security.SecurityErrorCode
- AUTHORIZOR_FAILED - 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 - org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.Features
- AUTO_CLEAN - org.apache.accumulo.core.fate.Fate.TxInfo
- AUTO_CLEAN - 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 - org.apache.accumulo.core.client.security.SecurityErrorCode
- BAD_AUTHORIZATIONS - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
- BAD_CREDENTIALS - org.apache.accumulo.core.client.security.SecurityErrorCode
- BAD_CREDENTIALS - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
- BAD_RANGE - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
- BAD_TSERVERS - 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 - org.apache.accumulo.core.client.admin.ScanType
- BATCH - org.apache.accumulo.core.tabletserver.thrift.ScanType
- BATCH - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
- BATCH_SCANNER - org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.Features
- BATCH_SCANNER_NUM_QUERY_THREADS - org.apache.accumulo.core.conf.ClientProperty
- BATCH_SCANNER_THREADS - org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.Features
- BATCH_SIZE - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
- BATCH_TIME_OUT - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
- BATCH_TIME_OUT - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
- BATCH_WRITER_CONFIG - org.apache.accumulo.core.clientImpl.mapreduce.lib.OutputConfigurator.WriteOpts
- BATCH_WRITER_DURABILITY - org.apache.accumulo.core.conf.ClientProperty
- BATCH_WRITER_LATENCY_MAX - org.apache.accumulo.core.conf.ClientProperty
- BATCH_WRITER_MEMORY_MAX - org.apache.accumulo.core.conf.ClientProperty
- BATCH_WRITER_THREADS_MAX - org.apache.accumulo.core.conf.ClientProperty
- BATCH_WRITER_TIMEOUT_MAX - 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 viaFormatterConfig
. - 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
- 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 - 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 - 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
- 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 - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
- BULK_BAD_INPUT_DIRECTORY - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
- BULK_BAD_LOAD_MAPPING - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
- BULK_CONCURRENT_MERGE - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
- BULK_IMPORT - org.apache.accumulo.core.clientImpl.thrift.TableOperation
- BULK_IMPORT - org.apache.accumulo.core.security.NamespacePermission
- BULK_IMPORT - org.apache.accumulo.core.security.TablePermission
- BULK_IMPORTS - org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
- BULK_IMPORTS - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- BULK_LOAD_MAPPING - Static variable in class org.apache.accumulo.core.Constants
- BULK_LOAD_THREADS - 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 - 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 - org.apache.accumulo.core.spi.scan.ScanServerAttempt.Result
- BUSY_TIMEOUT - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueMultiScan_args._Fields
- BUSY_TIMEOUT - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.continueScan_args._Fields
- BUSY_TIMEOUT - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
- BUSY_TIMEOUT - 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 - 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 - 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
-
Cancels a user initiated major compaction of a table initiated with
TableOperations.compact(String, Text, Text, boolean, boolean)
orTableOperations.compact(String, Text, Text, List, boolean, boolean)
. - 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 - org.apache.accumulo.core.compaction.thrift.TCompactionState
- 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 - org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
- CANNOT_AUTHENTICATE - org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
- CANNOT_AUTHENTICATE - org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorErrorCode
- CANNOT_INSTANTIATE_REPLAYER - 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 - 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 - 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 - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
-
Compaction initiated by merge operation
- CHOP - org.apache.accumulo.core.spi.compaction.CompactionKind
-
A compaction executed prior to merging tablets.
- CHOP - org.apache.accumulo.core.tabletserver.thrift.TCompactionKind
- CHOP - 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 - org.apache.accumulo.core.manager.thrift.TabletLoadState
- CHOPPED - 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 - org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- CLASS_LOADER_CONTEXT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
- CLASS_LOADER_CONTEXT - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
- CLASS_LOADER_CONTEXT - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startScan_args._Fields
- CLASS_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
- CLASS_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
- CLASS_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
- CLASS_NAME - org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
- CLASS_NAME - 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 - 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 - org.apache.accumulo.core.conf.PropertyType
- CLASSNAME - org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
- CLASSNAMELIST - 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 - 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 - 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 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.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 - org.apache.accumulo.core.singletons.SingletonManager.Mode
-
In this mode singletons are disabled when the number of active client reservations goes to zero.
- CLIENT - org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- CLIENT - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
- CLIENT_CONFIG - 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 - 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 - 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.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() - Static method in class org.apache.accumulo.core.metrics.MetricsUtil
- 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 - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
-
Compaction initiated to close a unload a tablet
- CLOSE - 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 - 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 - 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 - org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
- CODE - org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
- CODE - org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
- COL_FAMILY - org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
- COL_QUALIFIER - org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
- COL_VISIBILITY - 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 - org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
- COLUMN_QUALIFIER - org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
- COLUMN_VISIBILITY - 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 - org.apache.accumulo.core.clientImpl.mapreduce.lib.InputConfigurator.ScanOpts
- COLUMNS - org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- COLUMNS - org.apache.accumulo.core.tabletserver.thrift.TabletScanClientService.startMultiScan_args._Fields
- COLUMNS - 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 - 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 - org.apache.accumulo.core.clientImpl.thrift.TableOperation
- COMPACT_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
- COMPACT_ID - 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_CANCELED_MSG - Static variable in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
- COMPACTION_COORDINATOR_CLIENTPORT - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_DEAD_COMPACTOR_CHECK_INTERVAL - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_FINALIZER_COMPLETION_CHECK_INTERVAL - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_FINALIZER_TSERVER_NOTIFIER_MAXTHREADS - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_MAX_MESSAGE_SIZE - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_MINTHREADS - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_MINTHREADS_TIMEOUT - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_PREFIX - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_THREADCHECK - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_THRIFTCLIENT_PORTSEARCH - org.apache.accumulo.core.conf.Property
- COMPACTION_COORDINATOR_TSERVER_COMPACTION_CHECK_INTERVAL - org.apache.accumulo.core.conf.Property
- 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
-
The method parameters for
CompactionDispatcher.dispatch(DispatchParameters)
. - CompactionDispatcher.InitParameters - Interface in org.apache.accumulo.core.spi.compaction
-
The method parameters for
CompactionDispatcher.init(InitParameters)
. - 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 aCompactionJob
. - 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
-
The return value of
CompactionPlanner.makePlan(PlanningParameters)
that is created usingCompactionPlanner.PlanningParameters.createPlanBuilder()
- 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 - 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)
andCompactionConfig.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 - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost.Type
- COMPACTOR - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
- COMPACTOR - org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
- COMPACTOR - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.reserveCompactionJob_args._Fields
- COMPACTOR - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
- COMPACTOR_CLIENT - org.apache.accumulo.core.util.ServerServices.Service
- COMPACTOR_CLIENTPORT - org.apache.accumulo.core.conf.Property
- COMPACTOR_MAX_MESSAGE_SIZE - org.apache.accumulo.core.conf.Property
- COMPACTOR_MINTHREADS - org.apache.accumulo.core.conf.Property
- COMPACTOR_MINTHREADS_TIMEOUT - org.apache.accumulo.core.conf.Property
- COMPACTOR_PORTSEARCH - org.apache.accumulo.core.conf.Property
- COMPACTOR_PREFIX - org.apache.accumulo.core.conf.Property
- COMPACTOR_THREADCHECK - org.apache.accumulo.core.conf.Property
- 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 me