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
- ABlockReader - Interface in org.apache.accumulo.core.file.blockfile
- ABlockWriter - Interface in org.apache.accumulo.core.file.blockfile
- 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 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
- AbstractInputFormat<K,V> - Class in org.apache.accumulo.core.client.mapred
-
An abstract input format to provide shared methods common to all other input format classes.
- AbstractInputFormat<K,V> - Class in org.apache.accumulo.core.client.mapreduce
-
An abstract input format to provide shared methods common to all other input format classes.
- AbstractInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AbstractInputFormat
- AbstractInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
- AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapred
- AbstractInputFormat.AbstractRecordReader<K,V> - Class in org.apache.accumulo.core.client.mapreduce
- AbstractLexicoder<T> - Class in org.apache.accumulo.core.client.lexicoder.impl
- AbstractLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.impl.AbstractLexicoder
- AbstractRecordReader() - Constructor for class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
- AbstractRecordReader() - Constructor for class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
- accept(String) - Method in interface org.apache.accumulo.core.conf.AccumuloConfiguration.PropertyFilter
-
Deprecated.Determines whether to accept a property based on its key.
- 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 class org.apache.accumulo.core.iterators.Filter
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.system.SampleIterator
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.system.VisibilityFilter
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
-
Accepts entries whose timestamps are less than currentTime - threshold.
- accept(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.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
- AcceptableThriftTableOperationException - Exception in org.apache.accumulo.core.client.impl
-
Concrete implementation of
AcceptableException
for table operations. - AcceptableThriftTableOperationException(String, String, TableOperation, TableOperationExceptionType, String) - Constructor for exception org.apache.accumulo.core.client.impl.AcceptableThriftTableOperationException
- ACCEPTED - org.apache.accumulo.core.client.ConditionalWriter.Status
-
conditions were met and mutation was written
- ACCEPTED - org.apache.accumulo.core.data.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.CachedBlock
-
Block has been accessed.
- ACCUMULO_NAMESPACE - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
- ACCUMULO_NAMESPACE_ID - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
- ACCUMULO_PROPERTIES - org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator.Opts
- ACCUMULO_PROPERTIES - org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator.Opts
-
Deprecated.
- AccumuloConfiguration - Class in org.apache.accumulo.core.conf
-
A configuration object.
- AccumuloConfiguration() - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration
- AccumuloConfiguration.MatchFilter - Class in org.apache.accumulo.core.conf
-
A filter that accepts properties whose keys are an exact match.
- AccumuloConfiguration.PrefixFilter - Class in org.apache.accumulo.core.conf
-
A filter that accepts properties whose keys begin with a prefix.
- AccumuloConfiguration.PropertyFilter - Interface in org.apache.accumulo.core.conf
-
Deprecated.since 1.7.0; use
Predicate
instead. - 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
-
This class allows MapReduce jobs to write output in the Accumulo data file format.
Care should be taken to write only sorted data (sorted byKey
), as this is an important requirement of Accumulo data files. - AccumuloFileOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to write output in the Accumulo data file format.
Care should be taken to write only sorted data (sorted byKey
), as this is an important requirement of Accumulo data files. - AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
- AccumuloFileOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
- AccumuloInputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to use Accumulo as the source of data.
- AccumuloInputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to use Accumulo as the source of data.
- AccumuloInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloInputFormat
- AccumuloInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
- AccumuloMultiTableInputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to use multiple Accumulo tables as the source of data.
- AccumuloMultiTableInputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to use multiple Accumulo tables as the source of data.
- AccumuloMultiTableInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloMultiTableInputFormat
- AccumuloMultiTableInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
- AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to use Accumulo as the sink for data.
- AccumuloOutputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to use Accumulo as the sink for data.
- AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
- AccumuloOutputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
- AccumuloOutputFormat.AccumuloRecordWriter - Class in org.apache.accumulo.core.client.mapred
-
A base class to be used to create
RecordWriter
instances that write to Accumulo. - AccumuloOutputFormat.AccumuloRecordWriter - Class in org.apache.accumulo.core.client.mapreduce
-
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
- AccumuloRecordWriter(TaskAttemptContext) - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
- AccumuloReplicationReplayer - Interface in org.apache.accumulo.core.replication
- AccumuloRowInputFormat - Class in org.apache.accumulo.core.client.mapred
-
This class allows MapReduce jobs to use Accumulo as the source of data.
- AccumuloRowInputFormat - Class in org.apache.accumulo.core.client.mapreduce
-
This class allows MapReduce jobs to use Accumulo as the source of data.
- AccumuloRowInputFormat() - Constructor for class org.apache.accumulo.core.client.mapred.AccumuloRowInputFormat
- AccumuloRowInputFormat() - Constructor for class org.apache.accumulo.core.client.mapreduce.AccumuloRowInputFormat
- AccumuloSecurityException - Exception in org.apache.accumulo.core.client
-
An Accumulo Exception for security violations, authentication failures, authorization failures, etc.
- AccumuloSecurityException(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.client.impl
-
This class is intended to encapsulate errors that occurred on the server side.
- AccumuloServerException(String, TApplicationException) - Constructor for exception org.apache.accumulo.core.client.impl.AccumuloServerException
- 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
- 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, CompactionType, CompactionReason, String, long, long, List<IterInfo>, Map<String, Map<String, String>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- ActiveCompaction(ActiveCompaction) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Performs a deep copy on other.
- ActiveCompaction._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ActiveCompaction.CompactionReason - Enum in org.apache.accumulo.core.client.admin
- ActiveCompaction.CompactionType - Enum in org.apache.accumulo.core.client.admin
- ActiveCompactionImpl - Class in org.apache.accumulo.core.client.impl
- ActiveScan - Class in org.apache.accumulo.core.client.admin
-
A class that contains information about an ActiveScan
- ActiveScan - 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.client.impl
-
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(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, String, Value) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
-
Add a column update to the given mutation with the provided tableId and value
- add(Mutation, String, Value) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.StatusSection
- add(Mutation, Text, Value) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.WorkSection
- add(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.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.iterators.conf.ColumnSet
- add(Text, Text) - Method in class org.apache.accumulo.core.iterators.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.
- addCacheFile(URI, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
- addCondition(Condition) - Method in class org.apache.accumulo.core.data.ConditionalMutation
- addConfiguration(Configuration) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- addConfigurationListener(ConfigurationListener) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- addConstraint(String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Add a new constraint to a namespace.
- addConstraint(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Add a new constraint to a table.
- addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
- addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
- addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
- addConstraint(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- addErrorListener(ConfigurationErrorListener) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- addErrorLogListener() - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- addIterator(Class<?>, Configuration, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Encode an iterator on the input for the single input table associated with this job.
- addIterator(Class<?>, Configuration, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- addIterator(JobConf, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Encode an iterator on the input for this job.
- addIterator(Job, IteratorSetting) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Encode an iterator on the single input table for this job.
- 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
- addMutation(String, Iterator<Mutation>) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
- addMutation(String, Mutation) - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
- addMutation(String, Mutation) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- addMutation(KeyExtent, T) - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletServerMutations
- addMutation(Mutation) - Method in interface org.apache.accumulo.core.client.BatchWriter
-
Queues one mutation to write.
- addMutation(Mutation) - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
- addMutation(Mutation) - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
-
Deprecated.
- addMutations(Iterable<Mutation>) - Method in interface org.apache.accumulo.core.client.BatchWriter
-
Queues several mutations to write.
- addMutations(Iterable<Mutation>) - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
- addMutations(Iterable<Mutation>) - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
-
Deprecated.
- addNamedOption(String, String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
- addObject(Text, K) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
- addObject(Text, Text, K) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
- addObserver(ConfigurationObserver) - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
-
Adds an observer.
- addOption(String, String) - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Add another option to the iterator.
- addOption(String, String) - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
- addOptions(Map<String, String>) - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Add many options to the iterator.
- 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
-
Defines a cluster with the given name and the given name system.
- addPeer(String, String) - Method in class org.apache.accumulo.core.client.impl.ReplicationOperationsImpl
- addProperty(String, Object) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- addPropertyDirect(String, Object) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- addRange(Map<String, Map<KeyExtent, List<Range>>>, String, KeyExtent, Range) - Static method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- addReplicationSource(String) - Method in class org.apache.accumulo.core.data.Mutation
-
Add a new element to the set of peers which this Mutation originated from
- AddressUtil - Class in org.apache.accumulo.core.util
- AddressUtil() - Constructor for class org.apache.accumulo.core.util.AddressUtil
- addScanIterator(IteratorSetting) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- addScanIterator(IteratorSetting) - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Add a server-side scan iterator.
- addSource(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
- addSource(SortedKeyValueIterator<Key, Value>, IteratorEnvironment, Text, boolean) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
-
Deprecated.since 1.6.0
- addSplits(String, SortedSet<Text>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Ensures that tablets are split along a set of keys.
- addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- addSplits(String, SortedSet<Text>) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- addSplits(SortedSet<Text>) - Method in class org.apache.accumulo.core.client.mock.MockTable
-
Deprecated.
- addStat(long) - Method in class org.apache.accumulo.core.util.Stat
- addTable(Text) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
- addTable(Text) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
- addToArguments(ByteBuffer) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- addToAuthorizations(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- addToBulkImports(BulkImportStatus) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- 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.TabletClientService.startMultiScan_args
- addToColumns(TColumn) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- addToConditions(TCondition) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- addToDeadTabletServers(DeadServer) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- 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.client.impl.thrift.ClientService.bulkImportFiles_args
- addToFullScans(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- addToInputFiles(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- addToIterators(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- 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.master.thrift.MasterClientService.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.master.thrift.TabletSplit
- addToResults(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- addToResults(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- addToServersShuttingDown(String) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- addToSources(String) - Method in class org.apache.accumulo.core.data.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.TabletClientService.startMultiScan_args
- addToSsiList(IterInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- addToSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- addToSuccess(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- addToSuccess(String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.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.client.impl.thrift.ClientService.getUserAuthorizations_result
- addToSuccess(TDiskUsage) - Method in class org.apache.accumulo.core.client.impl.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.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- addToSuccess(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- addToSuccess(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- addToSymbols(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- addToTables(String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- addToTables(String) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- addToTServerInfo(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- addToValues(ByteBuffer) - Method in class org.apache.accumulo.core.data.thrift.TMutation
- addToViolationSummaries(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- addToViolationSummaries(TConstraintViolationSummary) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- addTTL(IteratorSetting, IteratorSetting.Column, Long) - Static method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
-
A convenience method for adding or changing an age off threshold for a column.
- addUnnamedOption(String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
- advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- advanceToIntersection() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- afterEndKey(Key) - Method in class org.apache.accumulo.core.data.Range
-
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
- AgeOffFilter - Class in org.apache.accumulo.core.iterators.user
-
A filter that ages off key/value pairs based on the Key's timestamp.
- AgeOffFilter() - Constructor for class org.apache.accumulo.core.iterators.user.AgeOffFilter
- aggregate() - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
-
Deprecated.
- aggregate() - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
-
Deprecated.
- aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
-
Generate statistics from each
Map.Entry
, called for each entry to be iterated over. - aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
- aggregateStats(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
- AggregatingFormatter - Class in org.apache.accumulo.core.util.format
-
Formatter that will aggregate entries for various display purposes.
- AggregatingFormatter() - Constructor for class org.apache.accumulo.core.util.format.AggregatingFormatter
- AggregatingIterator - Class in org.apache.accumulo.core.iterators
-
Deprecated.since 1.4, replaced by
Combiner
- AggregatingIterator() - Constructor for class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- AggregatingIterator(SortedKeyValueIterator<Key, Value>, ColumnToClassMapping<Aggregator>) - Constructor for class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- Aggregator - Interface in org.apache.accumulo.core.iterators.aggregation
-
Deprecated.since 1.4, replaced by
Combiner
- AggregatorConfiguration - Class in org.apache.accumulo.core.iterators.aggregation.conf
-
Deprecated.since 1.4
- AggregatorConfiguration(Text, String) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorConfiguration
-
Deprecated.
- AggregatorConfiguration(Text, Text, String) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorConfiguration
-
Deprecated.
- AggregatorSet - Class in org.apache.accumulo.core.iterators.aggregation.conf
-
Deprecated.since 1.4
- AggregatorSet() - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
-
Deprecated.
- AggregatorSet(Map<String, String>) - Constructor for class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
-
Deprecated.
- align(int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Aligns a number to 8.
- align(long) - Static method in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Aligns a number to 8.
- ALL_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
- 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
- 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, 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(Configuration) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- append(LoggingEvent) - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
- appendPrintableString(byte[], int, int, int, StringBuilder) - Static method in class org.apache.accumulo.core.data.Key
-
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(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration.MatchFilter
- apply(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration.PrefixFilter
- apply(String) - Method in interface org.apache.accumulo.core.conf.AccumuloConfiguration.PropertyFilter
-
Deprecated.
- 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) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- applyUpdates(TInfo, long, TKeyExtent, List<TMutation>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- applyUpdates_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, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.applyUpdates_call
- arguments - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- ARGUMENTS - org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
- ARRAY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Array overhead
- arrayAdd(List<Long>, List<Long>) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
- ArrayByteSequence - Class in org.apache.accumulo.core.data
-
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.
- ARRAYLIST - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ArrayList(0)
- asList() - Method in class org.apache.accumulo.core.constraints.Violations
-
Gets the violations as a list of summaries.
- ASSIGNING - org.apache.accumulo.core.master.thrift.BulkImportState
- asThriftException() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.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.master.thrift.FateService.AsyncClient
- AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.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
- AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor
- AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor
- AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor
- AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor
- AsyncProcessor(I) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.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, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.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.master.thrift.FateService.AsyncProcessor
- AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.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
- AsyncSocketAppender - Class in org.apache.accumulo.core.util
-
An asynchronous appender that maintains its own internal socket appender.
- AsyncSocketAppender() - Constructor for class org.apache.accumulo.core.util.AsyncSocketAppender
-
Creates a new appender.
- ATOMIC_BOOLEAN - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for AtomicBoolean
- ATOMIC_INTEGER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for AtomicInteger
- ATOMIC_LONG - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for AtomicLong
- attachIterator(String, IteratorSetting) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Add an iterator to a namespace on all scopes.
- attachIterator(String, IteratorSetting) - 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.client.impl.NamespaceOperationsHelper
- attachIterator(String, IteratorSetting) - Method in class org.apache.accumulo.core.client.impl.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.client.impl.NamespaceOperationsHelper
- attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
- attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
- attachIterator(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- AUTH - 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
- AuthConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.AuthConverter
- authenticate() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
- authenticate() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
- authenticate(TInfo, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- authenticate(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- authenticate(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- authenticate(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- authenticate_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- authenticate_args(ClientService.authenticate_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
Performs a deep copy on other.
- authenticate_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- authenticate_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticate_call
- authenticate_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- authenticate_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- authenticate_result(ClientService.authenticate_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
Performs a deep copy on other.
- authenticateUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
- authenticateUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
- authenticateUser(String, byte[]) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Deprecated.since 1.5.0; use
SecurityOperations.authenticateUser(String, AuthenticationToken)
instead. - authenticateUser(String, byte[]) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
Deprecated.
- 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.client.impl.SecurityOperationsImpl
- authenticateUser(TInfo, TCredentials, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- authenticateUser(TInfo, TCredentials, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- authenticateUser(TInfo, TCredentials, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- authenticateUser(TInfo, TCredentials, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- authenticateUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- authenticateUser_args(ClientService.authenticateUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
Performs a deep copy on other.
- authenticateUser_args(TInfo, TCredentials, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- authenticateUser_call(TInfo, TCredentials, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticateUser_call
- authenticateUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- authenticateUser_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- authenticateUser_result(ClientService.authenticateUser_result) - Constructor for class org.apache.accumulo.core.client.impl.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.client.impl
-
Implementation that identifies the underlying
Token
for Accumulo. - AuthenticationTokenIdentifier() - Constructor for class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- AuthenticationTokenIdentifier(String) - Constructor for class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- AuthenticationTokenIdentifier(String, int, long, long, String) - Constructor for class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- AuthenticationTokenIdentifier(String, DelegationTokenConfig) - Constructor for class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- AuthenticationTokenIdentifier(AuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- AuthenticationTokenIdentifier(TAuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- AuthenticationTokenSerializer() - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
- AUTHENTICATOR_FAILED - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- AUTHENTICATOR_FAILED - org.apache.accumulo.core.client.security.SecurityErrorCode
- AUTHORIZATION_FAILURES - org.apache.accumulo.core.data.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.data.thrift.UpdateErrors
- authorizations - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- authorizations - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
- authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- authorizations - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- 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.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
- AUTHORIZATIONS - org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.ScanOpts
- AUTHORIZATIONS - org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator.ScanOpts
-
Deprecated.
- 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.TabletClientService.startMultiScan_args._Fields
- AUTHORIZATIONS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- AUTHORIZOR_FAILED - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- AUTHORIZOR_FAILED - org.apache.accumulo.core.client.security.SecurityErrorCode
- auths - Variable in class org.apache.accumulo.core.cli.ClientOpts
- auths - Variable in class org.apache.accumulo.core.client.mock.MockScannerBase
-
Deprecated.
- AUTO_ADJUST_RANGES - org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.Features
- AUTO_ADJUST_RANGES - org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator.Features
-
Deprecated.
- AUTO_CLEAN - org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
- autoClean - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- available() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
- available() - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
- available() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
B
- BAD_AUTHORIZATIONS - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- BAD_AUTHORIZATIONS - org.apache.accumulo.core.client.security.SecurityErrorCode
- BAD_CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- BAD_CREDENTIALS - org.apache.accumulo.core.client.security.SecurityErrorCode
- BAD_RANGE - org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
- BAD_TSERVERS - org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
- BadArgumentException - Exception in org.apache.accumulo.core.util
- BadArgumentException(String, String, int) - Constructor for exception org.apache.accumulo.core.util.BadArgumentException
- badTServers - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- BaseIteratorEnvironment - Class in org.apache.accumulo.core.client.impl
-
An implementation of
IteratorEnvironment
that throwsUnsupportedOperationException
for each operation. - BaseIteratorEnvironment() - Constructor for class org.apache.accumulo.core.client.impl.BaseIteratorEnvironment
- basePath - Variable in class org.apache.accumulo.core.volume.VolumeImpl
- batch - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.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.TabletClientService.startMultiScan_args._Fields
- BATCH_SCANNER - org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.Features
- BATCH_SCANNER_THREADS - org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.Features
- BATCH_SIZE - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- BATCH_TIME_OUT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
- BATCH_TIME_OUT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- BATCH_WRITER_CONFIG - org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator.WriteOpts
- BATCH_WRITER_CONFIG - org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator.WriteOpts
-
Deprecated.
- 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.client.mapred.impl
-
The Class BatchInputSplit.
- BatchInputSplit - Class in org.apache.accumulo.core.client.mapreduce.impl
-
The Class BatchInputSplit.
- BatchInputSplit() - Constructor for class org.apache.accumulo.core.client.mapred.impl.BatchInputSplit
- BatchInputSplit() - Constructor for class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
- BatchInputSplit(String, String, Collection<Range>, String[]) - Constructor for class org.apache.accumulo.core.client.mapred.impl.BatchInputSplit
- BatchInputSplit(String, String, Collection<Range>, String[]) - Constructor for class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
- BatchInputSplit(BatchInputSplit) - Constructor for class org.apache.accumulo.core.client.mapred.impl.BatchInputSplit
- BatchInputSplit(BatchInputSplit) - Constructor for class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
- batchLatency - Variable in class org.apache.accumulo.core.cli.BatchWriterOpts
- batchMemory - Variable in class org.apache.accumulo.core.cli.BatchWriterOpts
- BatchScanner - Interface in org.apache.accumulo.core.client
-
In exchange for possibly returning scanned entries out of order, BatchScanner implementations may scan an Accumulo table more efficiently by Looking up multiple ranges in parallel.
- BatchScannerOpts - Class in org.apache.accumulo.core.cli
- BatchScannerOpts() - Constructor for class org.apache.accumulo.core.cli.BatchScannerOpts
- batchSize - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- batchThreads - Variable in class org.apache.accumulo.core.cli.BatchWriterOpts
- batchTimeout - Variable in class org.apache.accumulo.core.cli.BatchWriterOpts
- batchTimeOut - Variable in class org.apache.accumulo.core.client.impl.ScannerOptions
- batchTimeOut - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- batchTimeOut - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- BatchWriter - Interface in org.apache.accumulo.core.client
-
Send Mutations to a single Table in Accumulo.
- BatchWriterConfig - Class in org.apache.accumulo.core.client
-
This object holds configuration settings used to instantiate a
BatchWriter
- BatchWriterConfig() - Constructor for class org.apache.accumulo.core.client.BatchWriterConfig
- BatchWriterImpl - Class in org.apache.accumulo.core.client.impl
- BatchWriterImpl(ClientContext, String, BatchWriterConfig) - Constructor for class org.apache.accumulo.core.client.impl.BatchWriterImpl
- BatchWriterOpts - Class in org.apache.accumulo.core.cli
- BatchWriterOpts() - Constructor for class org.apache.accumulo.core.cli.BatchWriterOpts
- BCFile - Class in org.apache.accumulo.core.file.rfile.bcfile
-
Block Compressed file, the underlying physical storage layer for TFile.
- BCFile.Reader - Class in org.apache.accumulo.core.file.rfile.bcfile
-
BCFile Reader, interface to read the file's data and meta blocks.
- BCFile.Reader.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.master.thrift.FateService.AsyncProcessor.beginFateOperation
- beginFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor.beginFateOperation
- beginFateOperation(TInfo, TCredentials) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
- beginFateOperation(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.master.thrift.FateService.Iface
- beginFateOperation(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient
- beginFateOperation(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.FateService.AsyncIface
- beginFateOperation_args() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- beginFateOperation_args(FateService.beginFateOperation_args) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
-
Performs a deep copy on other.
- beginFateOperation_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- beginFateOperation_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.beginFateOperation_call
- beginFateOperation_result() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- beginFateOperation_result(long, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- beginFateOperation_result(FateService.beginFateOperation_result) - Constructor for class org.apache.accumulo.core.master.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.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.client.impl.RootTabletLocator
- binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.impl.SyncingTabletLocator
- binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
- binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
- binMutations(ClientContext, List<T>, Map<String, TabletLocator.TabletServerMutations<T>>, List<T>) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
-
Deprecated.
- binOffline(String, List<Range>, Instance, Connector) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
- binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
- binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.SyncingTabletLocator
- binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
- binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
- binRanges(ClientContext, List<Range>, Map<String, Map<KeyExtent, List<Range>>>) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
-
Deprecated.
- BlipSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
- BlockCache - Interface in org.apache.accumulo.core.file.blockfile.cache
-
Block cache interface.
- BlockedInputStream - Class in org.apache.accumulo.core.security.crypto
-
Reader corresponding to BlockedOutputStream.
- BlockedInputStream(InputStream, int, int) - Constructor for class org.apache.accumulo.core.security.crypto.BlockedInputStream
- BlockedOutputStream - Class in org.apache.accumulo.core.security.crypto
- BlockedOutputStream(OutputStream, int, int) - Constructor for class org.apache.accumulo.core.security.crypto.BlockedOutputStream
- BlockFileReader - Interface in org.apache.accumulo.core.file.blockfile
-
Provides a generic interface for a Reader for a BlockBaseFile format.
- BlockFileWriter - Interface in org.apache.accumulo.core.file.blockfile
-
Provides a generic interface for a Writer for a BlockBaseFile format.
- BlockIndex - Class in org.apache.accumulo.core.file.rfile
- BlockIndex() - Constructor for class org.apache.accumulo.core.file.rfile.BlockIndex
- BlockIndex.BlockIndexEntry - Class in org.apache.accumulo.core.file.rfile
- 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
- BlockRead(InputStream, long) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
- blocks - Variable in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
- BlockWrite(BCFile.Writer.BlockAppender) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
- 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
- buffer() - Method in interface org.apache.accumulo.core.file.rfile.bcfile.RawComparable
-
Get the underlying byte array.
- BufferedWriter(MultiLevelIndex.Writer) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.BufferedWriter
- bufferForCf() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- bufferForColFamily() - Method in class org.apache.accumulo.core.data.thrift.TKey
- bufferForColQualifier() - Method in class org.apache.accumulo.core.data.thrift.TKey
- bufferForColumnFamily() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- bufferForColumnQualifier() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- bufferForColumnVisibility() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- bufferForColVisibility() - Method in class org.apache.accumulo.core.data.thrift.TKey
- bufferForCq() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- bufferForCv() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- bufferForData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- bufferForEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- bufferForEndRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- bufferForEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- bufferForEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- bufferForIterators() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- bufferForPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- bufferForPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- bufferForPassword() - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- bufferForPrevEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- bufferForRow() - Method in class org.apache.accumulo.core.data.thrift.TKey
- bufferForRow() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- bufferForSecret() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- bufferForSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- bufferForStartRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- bufferForStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- bufferForStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- bufferForTable() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- bufferForToken() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- bufferForVal() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- bufferForValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- build() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration.Builder
-
Build the clone configuration
- build() - Method in class org.apache.accumulo.core.client.impl.CloneConfigurationImpl
- 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.file.FileOperations.OpenIndexOperation
- build() - Method in interface org.apache.accumulo.core.file.FileOperations.OpenIndexOperationBuilder
-
Construct the reader.
- build() - Method in class org.apache.accumulo.core.file.FileOperations.OpenReaderOperation
-
Execute the operation, constructing the specified file reader.
- build() - Method in interface org.apache.accumulo.core.file.FileOperations.OpenReaderOperationBuilder
-
Execute the operation, constructing the specified file reader.
- build() - Method in class org.apache.accumulo.core.file.FileOperations.OpenScanReaderOperation
-
Execute the operation, constructing a scan iterator.
- build() - Method in interface org.apache.accumulo.core.file.FileOperations.OpenScanReaderOperationBuilder
-
Execute the operation, constructing a scan iterator.
- build() - Method in class org.apache.accumulo.core.file.FileOperations.OpenWriterOperation
- build() - Method in interface org.apache.accumulo.core.file.FileOperations.OpenWriterOperationBuilder
-
Construct the writer.
- buildDocKey() - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- builder() - Static method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
- 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
- BULK_ARBITRATOR_TYPE - Static variable in class org.apache.accumulo.core.Constants
- BULK_BAD_ERROR_DIRECTORY - org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
- BULK_BAD_INPUT_DIRECTORY - org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
- BULK_IMPORT - org.apache.accumulo.core.client.impl.thrift.TableOperation
- BULK_IMPORT - org.apache.accumulo.core.security.NamespacePermission
- BULK_IMPORT - org.apache.accumulo.core.security.TablePermission
- BULK_IMPORTS - org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
- BULK_IMPORTS - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- BULK_PREFIX - Static variable in class org.apache.accumulo.core.Constants
- 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) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- bulkImport(TInfo, TCredentials, long, Map<TKeyExtent, Map<String, MapFileInfo>>, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- bulkImport_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, 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.
- bulkImportFiles() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
- bulkImportFiles() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
- bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- bulkImportFiles(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- bulkImportFiles_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- bulkImportFiles_args(ClientService.bulkImportFiles_args) - Constructor for class org.apache.accumulo.core.client.impl.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.client.impl.thrift.ClientService.bulkImportFiles_args
- bulkImportFiles_call(TInfo, TCredentials, long, String, List<String>, String, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.bulkImportFiles_call
- bulkImportFiles_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- bulkImportFiles_result(List<String>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- bulkImportFiles_result(ClientService.bulkImportFiles_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
Performs a deep copy on other.
- bulkImports - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- 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.
- BYTE_BUFFER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.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
- 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
- bytesToLong(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
-
Deprecated.
- bytesToLong(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
-
Deprecated.
- bytesToLong(byte[], int) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
-
Deprecated.
- bytesToLongArray(byte[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
-
Deprecated.
- ByteUtils - Class in org.apache.accumulo.core.client.lexicoder.impl
- ByteUtils() - Constructor for class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
C
- CachableBlockFile - Class in org.apache.accumulo.core.file.blockfile.impl
-
This is a wrapper class for BCFile that includes a cache for independent caches for datablocks and metadatablocks
- CachableBlockFile.BlockRead - Class in org.apache.accumulo.core.file.blockfile.impl
-
Class provides functionality to read one block from the underlying BCFile Since We are caching blocks in the Reader class as bytearrays, this class will wrap a DataInputStream(ByteArrayStream(cachedBlock)).
- CachableBlockFile.BlockWrite - 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.
- CachableBlockFile.Writer - Class in org.apache.accumulo.core.file.blockfile.impl
- cache - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
- cache - Variable in class org.apache.accumulo.core.iterators.user.VisibilityFilter
- CACHE_FIXED_OVERHEAD - Static variable in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
- cacheBlock(String, byte[]) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
-
Add block to cache (defaults to not in-memory).
- cacheBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Cache the block with the specified name and buffer.
- cacheBlock(String, byte[], boolean) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
-
Add block to cache.
- cacheBlock(String, byte[], boolean) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Cache the block with the specified name and buffer.
- CachedBlock - Class in org.apache.accumulo.core.file.blockfile.cache
-
Represents an entry in the
LruBlockCache
. - CachedBlock(String, byte[], long, boolean) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- CachedBlockQueue - Class in org.apache.accumulo.core.file.blockfile.cache
-
A memory-bound queue that will grow until an element brings total size >= maxSize.
- CachedBlockQueue(long, long) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
- CachedBlockRead(CacheEntry, byte[]) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
- cachedClientConfig - Variable in class org.apache.accumulo.core.cli.ClientOpts
- CachedConfiguration - Class in org.apache.accumulo.core.util
- CachedConfiguration() - Constructor for class org.apache.accumulo.core.util.CachedConfiguration
- cachedInstance - Variable in class org.apache.accumulo.core.cli.ClientOpts
- CacheEntry - Interface in org.apache.accumulo.core.file.blockfile.cache
- cacheMetaBlock(String, byte[]) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
- cacheMetaBlock(String, BCFile.Reader.BlockReader) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
- CacheStats() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- CachingHDFSSecretKeyEncryptionStrategy - Class in org.apache.accumulo.core.security.crypto
-
A
SecretKeyEncryptionStrategy
that gets its key from HDFS and caches it for IO. - CachingHDFSSecretKeyEncryptionStrategy() - Constructor for class org.apache.accumulo.core.security.crypto.CachingHDFSSecretKeyEncryptionStrategy
- calculateOverhead(long, long, int) - Static method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
- callbackHandler - Variable in class org.apache.accumulo.core.rpc.SaslConnectionParams
- CAN_CREATE_TABLES - org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator.Features
- CAN_CREATE_TABLES - org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator.Features
-
Deprecated.
- 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.client.impl.TableOperationsImpl
- canCreateTables(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
-
Determines whether tables are permitted to be created as needed.
- canCreateTables(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- canCreateTables(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Determines whether tables are permitted to be created as needed.
- canCreateTables(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Determines whether tables are permitted to be created as needed.
- 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
- canSee(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Indicates whether or not the user is able to see
key
. - canSeeColumnFamily(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Indicates whether or not
key
can be seen, according to the fetched column families for this iterator. - cf - Variable in class org.apache.accumulo.core.data.thrift.TCondition
- CF - org.apache.accumulo.core.data.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.master.thrift.MasterClientService.getDelegationToken_args
- CFG - org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args._Fields
- changeAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
- changeAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
- changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- changeAuthorizations_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- changeAuthorizations_args(ClientService.changeAuthorizations_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
Performs a deep copy on other.
- changeAuthorizations_args(TInfo, TCredentials, String, List<ByteBuffer>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- changeAuthorizations_call(TInfo, TCredentials, String, List<ByteBuffer>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeAuthorizations_call
- changeAuthorizations_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- changeAuthorizations_result(ClientService.changeAuthorizations_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
-
Performs a deep copy on other.
- changeAuthorizations_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- changeLocalUserPassword() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
- changeLocalUserPassword() - Constructor for class org.apache.accumulo.core.client.impl.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.client.impl.SecurityOperationsImpl
- changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- changeLocalUserPassword_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- changeLocalUserPassword_args(ClientService.changeLocalUserPassword_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
Performs a deep copy on other.
- changeLocalUserPassword_args(TInfo, TCredentials, String, ByteBuffer) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- changeLocalUserPassword_call(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
- changeLocalUserPassword_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- changeLocalUserPassword_result(ClientService.changeLocalUserPassword_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
-
Performs a deep copy on other.
- changeLocalUserPassword_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.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.client.impl.SecurityOperationsImpl
- changeUserPassword(String, byte[]) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Deprecated.since 1.5.0; use
SecurityOperations.changeLocalUserPassword(String, PasswordToken)
or the user management functions of your configured authenticator instead. - changeUserPassword(String, byte[]) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
Deprecated.
- check(Constraint.Environment, Mutation) - Method in interface org.apache.accumulo.core.constraints.Constraint
-
Checks a mutation for constraint violations.
- check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
- check(Constraint.Environment, Mutation) - Method in class org.apache.accumulo.core.constraints.VisibilityConstraint
- checkClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
- checkClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
- checkClass(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- checkClass(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- checkClass(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- checkClass(TInfo, TCredentials, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- checkClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- checkClass_args(ClientService.checkClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
Performs a deep copy on other.
- checkClass_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- checkClass_call(TInfo, TCredentials, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkClass_call
- checkClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- checkClass_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- checkClass_result(ClientService.checkClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
-
Performs a deep copy on other.
- checkDisjoint(Map<String, String>, SamplerConfiguration) - Static method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
- checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.
- checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Check whether a given iterator configuration conflicts with existing configuration; in particular, determine if the name or priority are already in use for the specified scopes.
- checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
- checkIteratorConflicts(String, IteratorSetting, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
- checkLocalityGroups(Iterable<Map.Entry<String, String>>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
- checkNamespaceClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
- checkNamespaceClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
- checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- checkNamespaceClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- checkNamespaceClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- checkNamespaceClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- checkNamespaceClass_args(ClientService.checkNamespaceClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
Performs a deep copy on other.
- checkNamespaceClass_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- checkNamespaceClass_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
- checkNamespaceClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- checkNamespaceClass_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- checkNamespaceClass_result(ClientService.checkNamespaceClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
Performs a deep copy on other.
- checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
- checkOutputSpecs(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
- checkState(boolean) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
- checkTableClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
- checkTableClass() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
- checkTableClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- checkTableClass(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- checkTableClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- checkTableClass(TInfo, TCredentials, String, String, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- checkTableClass_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- checkTableClass_args(ClientService.checkTableClass_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
Performs a deep copy on other.
- checkTableClass_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- checkTableClass_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkTableClass_call
- checkTableClass_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- checkTableClass_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- checkTableClass_result(ClientService.checkTableClass_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
Performs a deep copy on other.
- 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) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- chop(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- CHOP - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
-
Compaction initiated by merge operation
- CHOP - org.apache.accumulo.core.tabletserver.thrift.CompactionReason
- 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, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.chop_call
- CHOPPED - org.apache.accumulo.core.master.thrift.TabletLoadState
- 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
- CLASS - Static variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
- 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.TabletClientService.startMultiScan_args._Fields
- CLASS_LOADER_CONTEXT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- CLASS_NAME - org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
- CLASS_NAME - org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
- CLASS_NAME - org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
- CLASS_NAME - org.apache.accumulo.core.data.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.client.mapreduce.lib.impl.InputConfigurator.ScanOpts
- classLoaderContext - Variable in class org.apache.accumulo.core.client.impl.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.TabletClientService.startMultiScan_args
- classLoaderContext - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- className - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- className - Variable in class org.apache.accumulo.core.data.thrift.IterInfo
- className - Variable in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- CLASSNAME - org.apache.accumulo.core.conf.PropertyType
- CLASSNAMELIST - org.apache.accumulo.core.conf.PropertyType
- Classpath - Class in org.apache.accumulo.core.util
- Classpath() - Constructor for class org.apache.accumulo.core.util.Classpath
- ClassSize - Class in org.apache.accumulo.core.file.blockfile.cache
-
Class for determining the "size" of a class, an attempt to calculate the actual bytes that an object of this class will occupy in memory The core of this class is taken from the Derby project
- ClassSize() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.ClassSize
- CLEAN_STOP - org.apache.accumulo.core.master.thrift.MasterGoalState
- CleanUp - Class in org.apache.accumulo.core.util
- CleanUp() - Constructor for class org.apache.accumulo.core.util.CleanUp
- CLEANUP - org.apache.accumulo.core.master.thrift.BulkImportState
- clear() - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- clear() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- clear() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- clear() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- clear() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
- clear() - Method in 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.data.thrift.InitialMultiScan
- clear() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- clear() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- clear() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- clear() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- clear() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- clear() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- clear() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- clear() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- clear() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- clear() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- clear() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- clear() - Method in class org.apache.accumulo.core.data.thrift.TKey
- clear() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- clear() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- clear() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- clear() - Method in class org.apache.accumulo.core.data.thrift.TRange
- clear() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- clear() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- clear() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- clear() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- clear() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- clear() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
- clear() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- clear() - Method in class org.apache.accumulo.core.master.thrift.Compacting
- clear() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- clear() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- clear() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- clear() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- clear() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- clear() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- clear() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- clear() - Method in class org.apache.accumulo.core.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.security.thrift.TAuthenticationKey
- clear() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- clear() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- clear() - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- clear() - Method in class org.apache.accumulo.core.security.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.IteratorConfig
- clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
- clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.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.getActiveScans_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- clear() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- clear() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- clear() - Method in 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
- clearCache(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
- clearCacheByPath(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
-
Clears the zoo cache from instance/root/{PATH}
- clearClassLoaderContext() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
-
Clears the current classloader context set on this scanner
- clearClassLoaderContext() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- clearClassLoaderContext() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Clears the current classloader context set on this scanner
- clearColumns() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- clearColumns() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Clears the columns to be fetched (useful for resetting the scanner for reuse).
- clearConfigurationListeners() - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- clearErrorListeners() - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- clearInstance() - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
-
Clears the configuration properties in this configuration (but not the parent).
- 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.client.impl.TableOperationsImpl
- clearLocators() - Static method in class org.apache.accumulo.core.client.impl.TabletLocator
- clearOptions() - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Remove all options from the iterator.
- clearProperty(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- clearPropertyDirect(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- clearSamplerConfiguration() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- clearSamplerConfiguration() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Clears sampler configuration making a scanner read all data.
- 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.client.impl.TableOperationsImpl
- clearScanIterators() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- clearScanIterators() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Clears scan iterators prior to returning a scanner to the pool.
- client - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- client(T) - Static method in class org.apache.accumulo.core.trace.wrappers.TraceWrap
- Client(TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- Client(TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
- Client(TProtocol) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
- Client(TProtocol) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Client
- Client(TProtocol) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.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, TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.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.master.thrift.FateService.Client
- Client(TProtocol, TProtocol) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.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 - org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- CLIENT_CONFIG - org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.InstanceOpts
- clientConfigFile - Variable in class org.apache.accumulo.core.cli.ClientOpts
- ClientConfiguration - Class in org.apache.accumulo.core.client
-
Contains a list of property keys recognized by the Accumulo client and convenience methods for setting them.
- ClientConfiguration(File) - Constructor for class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API; use
ClientConfiguration.fromFile(File)
instead. - ClientConfiguration(String) - Constructor for class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API; use
ClientConfiguration.fromFile(File)
instead. - ClientConfiguration(List<? extends Configuration>) - Constructor for class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- ClientConfiguration(Configuration...) - Constructor for class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- ClientConfiguration.ClientProperty - Enum in org.apache.accumulo.core.client
- ClientContext - Class in org.apache.accumulo.core.client.impl
-
This class represents any essential configuration and credentials needed to initiate RPC operations throughout the code.
- ClientContext(Instance, Credentials, ClientConfiguration) - Constructor for class org.apache.accumulo.core.client.impl.ClientContext
-
Instantiate a client context
- ClientContext(Instance, Credentials, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.client.impl.ClientContext
-
Instantiate a client context from an existing
AccumuloConfiguration
. - ClientExec<T> - Interface in org.apache.accumulo.core.client.impl
- ClientExecReturn<T,C> - Interface in org.apache.accumulo.core.client.impl
- ClientOnDefaultTable - Class in org.apache.accumulo.core.cli
- ClientOnDefaultTable(String) - Constructor for class org.apache.accumulo.core.cli.ClientOnDefaultTable
- ClientOnRequiredTable - Class in org.apache.accumulo.core.cli
- ClientOnRequiredTable() - Constructor for class org.apache.accumulo.core.cli.ClientOnRequiredTable
- ClientOpts - Class in org.apache.accumulo.core.cli
- ClientOpts() - Constructor for class org.apache.accumulo.core.cli.ClientOpts
- ClientOpts.AuthConverter - Class in org.apache.accumulo.core.cli
- ClientOpts.MemoryConverter - Class in org.apache.accumulo.core.cli
- ClientOpts.Password - Class in org.apache.accumulo.core.cli
- ClientOpts.PasswordConverter - Class in org.apache.accumulo.core.cli
- ClientOpts.TimeConverter - Class in org.apache.accumulo.core.cli
- ClientOpts.VisibilityConverter - Class in org.apache.accumulo.core.cli
- ClientService - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService
- ClientService.AsyncClient - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.authenticate_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.authenticateUser_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.bulkImportFiles_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.changeAuthorizations_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.changeLocalUserPassword_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.checkClass_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.checkNamespaceClass_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.checkTableClass_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.createLocalUser_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.dropLocalUser_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.getConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.getDiskUsage_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.getInstanceId_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.getNamespaceConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.getRootTabletLocation_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.getTableConfiguration_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.getUserAuthorizations_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.getZooKeepers_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.grantNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.grantSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.grantTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.hasNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.hasSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.hasTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.isActive_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.listLocalUsers_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.ping_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.revokeNamespacePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.revokeSystemPermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncClient.revokeTablePermission_call - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncIface - Interface in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.authenticate<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.authenticateUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.bulkImportFiles<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.changeAuthorizations<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.changeLocalUserPassword<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.checkClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.checkNamespaceClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.checkTableClass<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.createLocalUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.dropLocalUser<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.getConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.getDiskUsage<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.getInstanceId<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.getNamespaceConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.getRootTabletLocation<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.getTableConfiguration<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.getUserAuthorizations<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.getZooKeepers<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.grantNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.grantSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.grantTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.hasNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.hasSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.hasTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.isActive<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.listLocalUsers<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.ping<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.revokeNamespacePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.revokeSystemPermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.AsyncProcessor.revokeTablePermission<I extends ClientService.AsyncIface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.authenticate_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.authenticate_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.authenticate_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.authenticate_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.authenticateUser_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.authenticateUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.authenticateUser_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.authenticateUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.bulkImportFiles_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.bulkImportFiles_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.bulkImportFiles_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.bulkImportFiles_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.changeAuthorizations_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.changeAuthorizations_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.changeAuthorizations_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.changeAuthorizations_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.changeLocalUserPassword_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.changeLocalUserPassword_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.changeLocalUserPassword_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.changeLocalUserPassword_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkClass_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.checkClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkClass_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.checkClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkNamespaceClass_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.checkNamespaceClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkNamespaceClass_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.checkNamespaceClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkTableClass_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.checkTableClass_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.checkTableClass_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.checkTableClass_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.Client - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Client.Factory - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.createLocalUser_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.createLocalUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.createLocalUser_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.createLocalUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.dropLocalUser_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.dropLocalUser_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.dropLocalUser_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.dropLocalUser_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getDiskUsage_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getDiskUsage_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getDiskUsage_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getDiskUsage_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getInstanceId_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getInstanceId_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getInstanceId_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getInstanceId_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getNamespaceConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getNamespaceConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getNamespaceConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getNamespaceConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getRootTabletLocation_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getRootTabletLocation_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getRootTabletLocation_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getRootTabletLocation_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getTableConfiguration_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getTableConfiguration_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getTableConfiguration_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getTableConfiguration_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getUserAuthorizations_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getUserAuthorizations_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getUserAuthorizations_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getUserAuthorizations_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getZooKeepers_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getZooKeepers_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.getZooKeepers_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.getZooKeepers_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.grantNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.grantNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.grantSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.grantSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.grantTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.grantTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.grantTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.hasNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.hasNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.hasSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.hasSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.hasTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.hasTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.hasTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.Iface - Interface in org.apache.accumulo.core.client.impl.thrift
- ClientService.isActive_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.isActive_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.isActive_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.isActive_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.listLocalUsers_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.listLocalUsers_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.listLocalUsers_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.listLocalUsers_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.ping_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.ping_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.ping_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.ping_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.Processor<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.authenticate<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.authenticateUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.bulkImportFiles<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.changeAuthorizations<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.changeLocalUserPassword<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.checkClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.checkNamespaceClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.checkTableClass<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.createLocalUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.dropLocalUser<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.getConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.getDiskUsage<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.getInstanceId<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.getNamespaceConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.getRootTabletLocation<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.getTableConfiguration<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.getUserAuthorizations<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.getZooKeepers<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.grantNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.grantSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.grantTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.hasNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.hasSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.hasTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.isActive<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.listLocalUsers<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.ping<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.revokeNamespacePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.revokeSystemPermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.Processor.revokeTablePermission<I extends ClientService.Iface> - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.revokeNamespacePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.revokeNamespacePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeNamespacePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.revokeNamespacePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeSystemPermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.revokeSystemPermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeSystemPermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.revokeSystemPermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeTablePermission_args - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.revokeTablePermission_args._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientService.revokeTablePermission_result - Class in org.apache.accumulo.core.client.impl.thrift
- ClientService.revokeTablePermission_result._Fields - Enum in org.apache.accumulo.core.client.impl.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ClientSideIteratorScanner - Class in org.apache.accumulo.core.client
-
A scanner that instantiates iterators on the client side instead of on the tablet server.
- ClientSideIteratorScanner(Scanner) - Constructor for class org.apache.accumulo.core.client.ClientSideIteratorScanner
-
Constructs a scanner that can execute client-side iterators.
- ClientSideIteratorScanner.ScannerTranslator - Class in org.apache.accumulo.core.client
-
Deprecated.since 1.7.0 was never intended for public use. However this could have been used by anything extending this class.
- 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 class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- clone() - Method in class org.apache.accumulo.core.client.mapreduce.impl.DelegationTokenStub
- 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.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.client.impl.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.client.impl.TableOperationsImpl
- CLONE - org.apache.accumulo.core.client.impl.thrift.TableOperation
- CLONE_EXCLUDE_PREFIX - Static variable in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- CLONE_PREFIX - Static variable in class org.apache.accumulo.core.Constants
- CLONE_PREFIX_BYTES - Static variable in class org.apache.accumulo.core.Constants
- 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.client.impl
-
A
CloneConfiguration
implementation which also implements the builder thereof - CloneConfigurationImpl() - Constructor for class org.apache.accumulo.core.client.impl.CloneConfigurationImpl
- ClonedColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ClonedColumnFamily
- cloneWithSamplingEnabled() - Method in class org.apache.accumulo.core.client.impl.BaseIteratorEnvironment
- 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.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 interface org.apache.accumulo.core.client.ConditionalWriter
-
release any resources (like threads pools) used by conditional writer
- close() - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
- close() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
- close() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- close() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
- close() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
- close() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
- close() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
- close() - Method in class org.apache.accumulo.core.client.mock.MockBatchScanner
-
Deprecated.
- close() - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
-
Deprecated.
- close() - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
-
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 interface org.apache.accumulo.core.file.blockfile.ABlockReader
- close() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
- close() - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
- close() - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileWriter
- close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
- close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
- close() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
- close() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
- close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- close() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
- close() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
- close() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
- close() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
-
Finishing reading the block.
- close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
-
Finishing reading the BCFile.
- close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
-
Signaling the end of write to the block.
- close() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
-
Close the BCFile Writer.
- close() - 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.iterators.system.MapFileIterator
- close() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- close() - Method in class org.apache.accumulo.core.rpc.FilterTransport
- close() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
- close() - Method in class org.apache.accumulo.core.security.crypto.BlockedOutputStream
- close() - Method in class org.apache.accumulo.core.security.crypto.DiscardCloseOutputStream
- close(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(MasterClientService.Iface) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
- close(ReplicationCoordinator.Iface) - Static method in class org.apache.accumulo.core.client.impl.ReplicationClient
- close(ReplicationServicer.Iface) - Static method in class org.apache.accumulo.core.client.impl.ReplicationClient
- close(Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat.AccumuloRecordWriter
- close(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat.AccumuloRecordWriter
- close(TServiceClient) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- CLOSE - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
-
Compaction initiated to close a unload a tablet
- CLOSE - org.apache.accumulo.core.tabletserver.thrift.CompactionReason
- 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) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- closeConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- closeConditionalUpdate_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, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeConditionalUpdate_call
- closeDeepCopies() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- closeDeepCopies() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
- closeDeepCopies() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- closeDeepCopies() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- closeDeepCopies() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- closeDeepCopies() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- closeMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
- closeMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeMultiScan
- closeMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- closeMultiScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- closeMultiScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- closeMultiScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- closeMultiScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- closeMultiScan_args(TabletClientService.closeMultiScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
-
Performs a deep copy on other.
- closeMultiScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- closeMultiScan_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeMultiScan_call
- closeMultiScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- closeMultiScan_result(NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- closeMultiScan_result(TabletClientService.closeMultiScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
-
Performs a deep copy on other.
- closeScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
- closeScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeScan
- closeScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- closeScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- closeScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- closeScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- closeScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- closeScan_args(TabletClientService.closeScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
-
Performs a deep copy on other.
- closeScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- closeScan_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.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) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- closeUpdate(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- closeUpdate_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, 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.
- cmid - Variable in class org.apache.accumulo.core.data.thrift.TCMResult
- CMID - org.apache.accumulo.core.data.thrift.TCMResult._Fields
- code - Variable in exception org.apache.accumulo.core.client.impl.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.client.impl.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.data.thrift.TKey._Fields
- COL_QUALIFIER - org.apache.accumulo.core.data.thrift.TKey._Fields
- COL_VISIBILITY - org.apache.accumulo.core.data.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.data.thrift.TKey
- colFamSet - Variable in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
- collect(Value) - Method in interface org.apache.accumulo.core.iterators.aggregation.Aggregator
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringMax
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringMin
-
Deprecated.
- collect(Value) - Method in class org.apache.accumulo.core.iterators.aggregation.StringSummation
-
Deprecated.
- COLQ_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
- colQualifier - Variable in class org.apache.accumulo.core.data.Key
- colQualifier - Variable in class org.apache.accumulo.core.data.thrift.TKey
- Column - Class in org.apache.accumulo.core.data
-
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.data.thrift.TColumn._Fields
- COLUMN_QUALIFIER - org.apache.accumulo.core.data.thrift.TColumn._Fields
- COLUMN_VISIBILITY - org.apache.accumulo.core.data.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.iterators.system.LocalityGroupIterator.LocalityGroup
- columnFamily - Variable in class org.apache.accumulo.core.data.Column
- columnFamily - Variable in class org.apache.accumulo.core.data.thrift.TColumn
- ColumnFamilyCounter - Class in org.apache.accumulo.core.iterators
- ColumnFamilyCounter() - Constructor for class org.apache.accumulo.core.iterators.ColumnFamilyCounter
- ColumnFamilyFunctor - Class in org.apache.accumulo.core.file.keyfunctor
- ColumnFamilyFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
- ColumnFamilySkippingIterator - Class in org.apache.accumulo.core.iterators.system
- ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
- ColumnFamilySkippingIterator(SortedKeyValueIterator<Key, Value>, Set<ByteSequence>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
- ColumnFQ - Class in org.apache.accumulo.core.util
- ColumnFQ(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.data.thrift.TColumn
- ColumnQualifierFilter - Class in org.apache.accumulo.core.iterators.system
- ColumnQualifierFilter(SortedKeyValueIterator<Key, Value>, Set<Column>) - Constructor for class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
- ColumnQualifierFunctor - Class in org.apache.accumulo.core.file.keyfunctor
- ColumnQualifierFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor
- columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- columns - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- COLUMNS - org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.ScanOpts
- COLUMNS - org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator.ScanOpts
-
Deprecated.
- COLUMNS - org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- COLUMNS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
- COLUMNS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.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.iterators.conf
- ColumnSet() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnSet
- ColumnSet(Collection<String>) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnSet
- ColumnSliceFilter - Class in org.apache.accumulo.core.iterators.user
- ColumnSliceFilter() - Constructor for class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
- ColumnToClassMapping<K> - Class in org.apache.accumulo.core.iterators.conf
- ColumnToClassMapping() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
- ColumnToClassMapping(Map<String, String>, Class<? extends K>) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
- ColumnToClassMapping(Map<String, String>, Class<? extends K>, String) - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
- ColumnTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.ColumnTranslator
- 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.iterators.conf
- ColumnUtil() - Constructor for class org.apache.accumulo.core.iterators.conf.ColumnUtil
- ColumnUtil.ColFamHashKey - Class in org.apache.accumulo.core.iterators.conf
- ColumnUtil.ColHashKey - Class in org.apache.accumulo.core.iterators.conf
- columnVisibility - Variable in class org.apache.accumulo.core.data.Column
- columnVisibility - Variable in class org.apache.accumulo.core.data.thrift.TColumn
- ColumnVisibility - Class in org.apache.accumulo.core.security
-
Validate the column visibility is a valid expression and set the visibility for a Mutation.
- ColumnVisibility() - Constructor for class org.apache.accumulo.core.security.ColumnVisibility
-
Creates an empty visibility.
- ColumnVisibility(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.data.thrift.TKey
- Combiner - Class in org.apache.accumulo.core.iterators
-
A SortedKeyValueIterator that combines the Values for different versions (timestamp) of a Key within a row into a single Value.
- Combiner() - Constructor for class org.apache.accumulo.core.iterators.Combiner
- COMBINER_NAME - Static variable in class org.apache.accumulo.core.replication.ReplicationTable
- 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.client.impl.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.client.impl.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.client.impl.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) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- COMPACT - org.apache.accumulo.core.client.impl.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, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compact_call
- COMPACT_CANCEL - org.apache.accumulo.core.client.impl.thrift.TableOperation
- COMPACT_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
-
Holds compact IDs to enable waiting on a compaction to complete
- 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.
- 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
- CompactionReason - Enum in org.apache.accumulo.core.tabletserver.thrift
- CompactionSettings - Enum in org.apache.accumulo.core.compaction
- CompactionStrategyConfig - Class in org.apache.accumulo.core.client.admin
-
Configuration object which describes how a Compaction is run.
- CompactionStrategyConfig(String) - Constructor for class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
- CompactionStrategyConfigUtil - Class in org.apache.accumulo.core.client.impl
- CompactionStrategyConfigUtil() - Constructor for class org.apache.accumulo.core.client.impl.CompactionStrategyConfigUtil
- CompactionType - Enum in org.apache.accumulo.core.tabletserver.thrift
- ComparableBytes - Class in org.apache.accumulo.core.data
-
Deprecated.since 1.7.0 In an attempt to clean up types in the data package that were not intended to be in public API this type was deprecated. Technically this method was not considered part of the public API in 1.6.0 and earlier, therefore it could have been deleted. However a decision was made to deprecate in order to be cautious and avoid confusion between 1.6.0 and 1.7.0.
- ComparableBytes - Class in org.apache.accumulo.core.data.impl
-
An array of bytes wrapped so as to extend Hadoop's
BinaryComparable
class. - ComparableBytes(byte[]) - Constructor for class org.apache.accumulo.core.data.ComparableBytes
-
Deprecated.Creates a new byte wrapper.
- ComparableBytes(byte[]) - Constructor for class org.apache.accumulo.core.data.impl.ComparableBytes
-
Creates a new byte wrapper.
- ComparablePair<A extends Comparable<A>,B extends Comparable<B>> - Class in org.apache.accumulo.core.util
- ComparablePair(A, B) - Constructor for class org.apache.accumulo.core.util.ComparablePair
- Comparator() - Constructor for class org.apache.accumulo.core.data.Value.Comparator
-
constructor
- compare(byte[], byte[]) - Method in class org.apache.accumulo.core.util.ByteArrayComparator
- compare(byte[], int, int, byte[], int, int) - Method in class org.apache.accumulo.core.data.Value.Comparator
- compare(IterInfo, IterInfo) - Method in class org.apache.accumulo.core.iterators.IteratorUtil.IterInfoComparator
- compare(ColumnVisibility.Node, ColumnVisibility.Node) - Method in class org.apache.accumulo.core.security.ColumnVisibility.NodeComparator
- compareBytes(ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.data.ByteSequence
-
Compares the two given byte sequences, byte by byte, returning a negative, zero, or positive result if the first sequence is less than, equal to, or greater than the second.
- compareColumnFamily(Text) - Method in class org.apache.accumulo.core.data.Key
-
Compares this key's column family with another.
- compareColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
-
Compares this key's column qualifier with another.
- compareRow(Text) - Method in class org.apache.accumulo.core.data.Key
-
Compares this key's row ID with another.
- compareTo(byte[]) - Method in class org.apache.accumulo.core.data.Value
-
Compares the bytes in this object to the specified byte array
- compareTo(Object) - Method in class org.apache.accumulo.core.data.Value
-
Define the sort order of the BytesWritable.
- compareTo(TabletLocator.TabletLocation) - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
- compareTo(ClientService.authenticate_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- compareTo(ClientService.authenticate_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- compareTo(ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- compareTo(ClientService.authenticateUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- compareTo(ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- compareTo(ClientService.bulkImportFiles_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- compareTo(ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- compareTo(ClientService.changeAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- compareTo(ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- compareTo(ClientService.changeLocalUserPassword_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- compareTo(ClientService.checkClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- compareTo(ClientService.checkClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- compareTo(ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- compareTo(ClientService.checkNamespaceClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- compareTo(ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- compareTo(ClientService.checkTableClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- compareTo(ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- compareTo(ClientService.createLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- compareTo(ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- compareTo(ClientService.dropLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- compareTo(ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- compareTo(ClientService.getConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- compareTo(ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- compareTo(ClientService.getDiskUsage_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- compareTo(ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- compareTo(ClientService.getInstanceId_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- compareTo(ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- compareTo(ClientService.getNamespaceConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- compareTo(ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- compareTo(ClientService.getRootTabletLocation_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- compareTo(ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- compareTo(ClientService.getTableConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- compareTo(ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- compareTo(ClientService.getUserAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- compareTo(ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- compareTo(ClientService.getZooKeepers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- compareTo(ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- compareTo(ClientService.grantNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- compareTo(ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- compareTo(ClientService.grantSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- compareTo(ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- compareTo(ClientService.grantTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- compareTo(ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- compareTo(ClientService.hasNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- compareTo(ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- compareTo(ClientService.hasSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- compareTo(ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- compareTo(ClientService.hasTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- compareTo(ClientService.isActive_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- compareTo(ClientService.isActive_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- compareTo(ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- compareTo(ClientService.listLocalUsers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- compareTo(ClientService.ping_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- compareTo(ClientService.ping_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- compareTo(ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- compareTo(ClientService.revokeNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- compareTo(ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- compareTo(ClientService.revokeSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- compareTo(ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- compareTo(ClientService.revokeTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- compareTo(TDiskUsage) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- compareTo(ThriftSecurityException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- compareTo(ThriftTableOperationException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- compareTo(ThriftTest.fails_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- compareTo(ThriftTest.fails_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- compareTo(ThriftTest.success_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- compareTo(ThriftTest.success_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- compareTo(ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- compareTo(ThriftTest.throwsError_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- compareTo(AuthenticationToken.TokenProperty) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
- compareTo(ByteSequence) - Method in class org.apache.accumulo.core.data.ByteSequence
- compareTo(Column) - Method in class org.apache.accumulo.core.data.Column
-
Compares this column to another.
- compareTo(KeyExtent) - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- compareTo(Key) - Method in class org.apache.accumulo.core.data.Key
- compareTo(KeyExtent) - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- compareTo(Key, PartialKey) - Method in class org.apache.accumulo.core.data.Key
-
Compares elements of a key given by a
PartialKey
. - compareTo(Range) - Method in class org.apache.accumulo.core.data.Range
-
Compares this range to another range.
- compareTo(TabletId) - Method in class org.apache.accumulo.core.data.impl.TabletIdImpl
- compareTo(InitialMultiScan) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- compareTo(InitialScan) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- compareTo(IterInfo) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- compareTo(MapFileInfo) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- compareTo(MultiScanResult) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- compareTo(ScanResult) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- compareTo(TCMResult) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- compareTo(TColumn) - Method in class org.apache.accumulo.core.data.thrift.TColumn
- compareTo(TCondition) - Method in class org.apache.accumulo.core.data.thrift.TCondition
- compareTo(TConditionalMutation) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- compareTo(TConditionalSession) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- compareTo(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- compareTo(TKey) - Method in class org.apache.accumulo.core.data.thrift.TKey
- compareTo(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- compareTo(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- compareTo(TMutation) - Method in class org.apache.accumulo.core.data.thrift.TMutation
- compareTo(TRange) - Method in class org.apache.accumulo.core.data.thrift.TRange
- compareTo(UpdateErrors) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- compareTo(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- compareTo(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
- compareTo(BlockIndex.BlockIndexEntry) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
- compareTo(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- compareTo(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- compareTo(GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- compareTo(GCMonitorService.getStatus_result) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- compareTo(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- compareTo(OrIterator.TermSource) - Method in class org.apache.accumulo.core.iterators.OrIterator.TermSource
- compareTo(BulkImportStatus) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- compareTo(Compacting) - Method in class org.apache.accumulo.core.master.thrift.Compacting
- compareTo(DeadServer) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- compareTo(FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- compareTo(FateService.beginFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- compareTo(FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- compareTo(FateService.executeFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- compareTo(FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- compareTo(FateService.finishFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- compareTo(FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- compareTo(FateService.waitForFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- compareTo(MasterClientService.drainReplicationTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- compareTo(MasterClientService.drainReplicationTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- compareTo(MasterClientService.getActiveTservers_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- compareTo(MasterClientService.getActiveTservers_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- compareTo(MasterClientService.getDelegationToken_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- compareTo(MasterClientService.getDelegationToken_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- compareTo(MasterClientService.getMasterStats_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- compareTo(MasterClientService.getMasterStats_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- compareTo(MasterClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- compareTo(MasterClientService.initiateFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- compareTo(MasterClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- compareTo(MasterClientService.removeNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- compareTo(MasterClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- compareTo(MasterClientService.removeSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- compareTo(MasterClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- compareTo(MasterClientService.removeTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- compareTo(MasterClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- compareTo(MasterClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- compareTo(MasterClientService.setMasterGoalState_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- compareTo(MasterClientService.setMasterGoalState_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- compareTo(MasterClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- compareTo(MasterClientService.setNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- compareTo(MasterClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- compareTo(MasterClientService.setSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- compareTo(MasterClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- compareTo(MasterClientService.setTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- compareTo(MasterClientService.shutdown_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- compareTo(MasterClientService.shutdown_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- compareTo(MasterClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- compareTo(MasterClientService.shutdownTabletServer_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- compareTo(MasterClientService.waitForBalance_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- compareTo(MasterClientService.waitForBalance_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
- compareTo(MasterClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- compareTo(MasterClientService.waitForFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- compareTo(MasterMonitorInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- compareTo(RecoveryException) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- compareTo(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- compareTo(TableInfo) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- compareTo(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- compareTo(TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- compareTo(KeyValues) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- compareTo(RemoteReplicationException) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- compareTo(ReplicationCoordinator.getServicerAddress_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- compareTo(ReplicationCoordinator.getServicerAddress_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- compareTo(ReplicationCoordinatorException) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- compareTo(ReplicationServicer.replicateKeyValues_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- compareTo(ReplicationServicer.replicateKeyValues_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- compareTo(ReplicationServicer.replicateLog_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- compareTo(ReplicationServicer.replicateLog_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- compareTo(WalEdits) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- compareTo(TAuthenticationKey) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- compareTo(TAuthenticationTokenIdentifier) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- compareTo(TCredentials) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- compareTo(TDelegationToken) - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- compareTo(TDelegationTokenConfig) - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- compareTo(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- compareTo(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- compareTo(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- compareTo(ConstraintViolationException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- compareTo(IteratorConfig) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- compareTo(NoSuchScanIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
- compareTo(NotServingTabletException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- compareTo(TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- compareTo(TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- compareTo(TabletClientService.bulkImport_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- compareTo(TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- compareTo(TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- compareTo(TabletClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- compareTo(TabletClientService.closeMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- compareTo(TabletClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- compareTo(TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- compareTo(TabletClientService.closeUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- compareTo(TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- compareTo(TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- compareTo(TabletClientService.conditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- compareTo(TabletClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- compareTo(TabletClientService.continueMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- compareTo(TabletClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- compareTo(TabletClientService.continueScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- compareTo(TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- compareTo(TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- compareTo(TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- compareTo(TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- compareTo(TabletClientService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- compareTo(TabletClientService.getActiveLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- compareTo(TabletClientService.getActiveLogs_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- compareTo(TabletClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- compareTo(TabletClientService.getActiveScans_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- compareTo(TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- compareTo(TabletClientService.getHistoricalStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- compareTo(TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- compareTo(TabletClientService.getTabletServerStatus_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- compareTo(TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- compareTo(TabletClientService.getTabletStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- compareTo(TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- compareTo(TabletClientService.halt_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- compareTo(TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- compareTo(TabletClientService.invalidateConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- compareTo(TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- compareTo(TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- compareTo(TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- compareTo(TabletClientService.splitTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- compareTo(TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- compareTo(TabletClientService.startConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- compareTo(TabletClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- compareTo(TabletClientService.startMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- compareTo(TabletClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- compareTo(TabletClientService.startScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- compareTo(TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- compareTo(TabletClientService.startUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- compareTo(TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- compareTo(TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- compareTo(TabletClientService.update_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- compareTo(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- compareTo(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- compareTo(TooManyFilesException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- compareTo(TSampleNotPresentException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- compareTo(TSamplerConfiguration) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- compareTo(TInfo) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- compareTo(ColumnFQ) - Method in class org.apache.accumulo.core.util.ColumnFQ
- compareTo(ComparablePair<A, B>) - Method in class org.apache.accumulo.core.util.ComparablePair
- compareTo(ServerServices) - Method in class org.apache.accumulo.core.util.ServerServices
- compatibleWith(Utils.Version) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
-
Test compatibility.
- compress(List<? extends KeyValue>) - Static method in class org.apache.accumulo.core.data.Key
-
Compresses a list of key/value pairs before sending them via thrift.
- compress(IteratorSetting[]) - Method in class org.apache.accumulo.core.client.impl.CompressedIterators
- CompressedIterators - Class in org.apache.accumulo.core.client.impl
- CompressedIterators() - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators
- CompressedIterators(List<String>) - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators
- CompressedIterators.IterConfig - Class in org.apache.accumulo.core.client.impl
- Compression - Class in org.apache.accumulo.core.file.rfile.bcfile
-
Compression related stuff.
- COMPRESSION_GZ - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
-
compression: gzip
- COMPRESSION_LZO - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
-
compression: lzo
- COMPRESSION_NONE - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
-
compression: none
- COMPRESSION_SNAPPY - Static variable in class org.apache.accumulo.core.file.rfile.bcfile.Compression
-
snappy codec
- Compression.Algorithm - Enum in org.apache.accumulo.core.file.rfile.bcfile
-
Compression algorithms.
- computeReseekRange(Range) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Possibly expand
range
to include everything for the key prefix we are working with. - concat(byte[]...) - Static method in class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
-
Concatenates byte arrays with 0x00 as a delimiter
- CONCURRENT_HASHMAP - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentHashMap
- CONCURRENT_HASHMAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentHashMap.Entry
- CONCURRENT_HASHMAP_SEGMENT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentHashMap.Segment
- CONCURRENT_SKIPLISTMAP - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentSkipListMap
- CONCURRENT_SKIPLISTMAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for ConcurrentSkipListMap Entry
- Condition - Class in org.apache.accumulo.core.data
-
Conditions that must be met on a particular column in a row.
- Condition(byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Condition
-
Creates a new condition.
- Condition(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Condition
-
Creates a new condition.
- Condition(ByteSequence, ByteSequence) - Constructor for class org.apache.accumulo.core.data.Condition
-
Creates a new condition.
- Condition(Text, Text) - Constructor for class org.apache.accumulo.core.data.Condition
-
Creates a new condition.
- ConditionalMutation - Class in org.apache.accumulo.core.data
-
A Mutation that contains a list of conditions that must all be met before the mutation is applied.
- ConditionalMutation(byte[], int, int, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
- ConditionalMutation(byte[], Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
- ConditionalMutation(CharSequence, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
- ConditionalMutation(ByteSequence, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
- ConditionalMutation(ConditionalMutation) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
- ConditionalMutation(Text, Condition...) - Constructor for class org.apache.accumulo.core.data.ConditionalMutation
- conditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
- conditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
- conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- conditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- conditionalUpdate_args(TabletClientService.conditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
Performs a deep copy on other.
- conditionalUpdate_args(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- conditionalUpdate_call(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.conditionalUpdate_call
- conditionalUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- conditionalUpdate_result(List<TCMResult>, NoSuchScanIDException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- conditionalUpdate_result(TabletClientService.conditionalUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
-
Performs a deep copy on other.
- ConditionalWriter - Interface in org.apache.accumulo.core.client
-
ConditionalWriter provides the ability to do efficient, atomic read-modify-write operations on rows.
- ConditionalWriter.Result - Class in org.apache.accumulo.core.client
- ConditionalWriter.Status - Enum in org.apache.accumulo.core.client
- ConditionalWriterConfig - Class in org.apache.accumulo.core.client
- ConditionalWriterConfig() - Constructor for class org.apache.accumulo.core.client.ConditionalWriterConfig
- conditions - Variable in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- CONDITIONS - org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
- conf - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- CONF_LZO_CLASS - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- CONF_SNAPPY_CLASS - Static variable in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- config - Variable in class org.apache.accumulo.core.util.format.DefaultFormatter
- ConfigSanityCheck - Class in org.apache.accumulo.core.conf
-
A utility class for validating
AccumuloConfiguration
instances. - ConfigSanityCheck() - Constructor for class org.apache.accumulo.core.conf.ConfigSanityCheck
- ConfigSanityCheck.SanityCheckException - Exception in org.apache.accumulo.core.conf
-
The exception thrown when
ConfigSanityCheck.validate(Iterable)
fails. - ConfigurationCopy - Class in org.apache.accumulo.core.conf
-
An
AccumuloConfiguration
which holds a flat copy of properties defined in another configuration - ConfigurationCopy() - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
-
Creates a new empty configuration.
- ConfigurationCopy(Iterable<Map.Entry<String, String>>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
-
Creates a new configuration.
- ConfigurationCopy(Map<String, String>) - Constructor for class org.apache.accumulo.core.conf.ConfigurationCopy
-
Creates a new configuration.
- ConfigurationObserver - Interface in org.apache.accumulo.core.conf
- ConfigurationType - Enum in org.apache.accumulo.core.client.impl.thrift
- ConfiguratorBase - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
- ConfiguratorBase - Class in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- ConfiguratorBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
- ConfiguratorBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.
- ConfiguratorBase.ConnectorInfo - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
Configuration keys for
Instance.getConnector(String, AuthenticationToken)
. - ConfiguratorBase.ConnectorInfo - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- ConfiguratorBase.GeneralOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
Configuration keys for general configuration options.
- ConfiguratorBase.GeneralOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- ConfiguratorBase.InstanceOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
Configuration keys for available
Instance
types. - ConfiguratorBase.InstanceOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- ConfiguratorBase.TokenSource - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
- conn - Variable in class org.apache.accumulo.core.client.impl.ClientContext
- CONNECTION_ERROR - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- CONNECTION_ERROR - org.apache.accumulo.core.client.security.SecurityErrorCode
- Connector - Class in org.apache.accumulo.core.client
-
Connector connects to an Accumulo instance and allows the user to request readers and writers for the instance as well as various objects that permit administrative operations.
- Connector() - Constructor for class org.apache.accumulo.core.client.Connector
- ConnectorImpl - Class in org.apache.accumulo.core.client.impl
- ConnectorImpl(ClientContext) - Constructor for class org.apache.accumulo.core.client.impl.ConnectorImpl
- Constants - Class in org.apache.accumulo.core
- Constants() - Constructor for class org.apache.accumulo.core.Constants
- CONSTRAIN_CLASS - org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
- constrainClass - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
- constrainClass - Variable in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- Constraint - Interface in org.apache.accumulo.core.constraints
-
Constraint objects are used to determine if mutations will be applied to a table.
- Constraint.Environment - Interface in org.apache.accumulo.core.constraints
-
The environment within which a constraint exists.
- ConstraintViolationException - Exception in org.apache.accumulo.core.tabletserver.thrift
- ConstraintViolationException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- ConstraintViolationException(List<TConstraintViolationSummary>) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- ConstraintViolationException(ConstraintViolationException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
Performs a deep copy on other.
- ConstraintViolationException._Fields - Enum in org.apache.accumulo.core.tabletserver.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- ConstraintViolationSummary - Class in org.apache.accumulo.core.data
-
A summary of constraint violations across some number of mutations.
- ConstraintViolationSummary(String, short, String, long) - Constructor for class org.apache.accumulo.core.data.ConstraintViolationSummary
-
Creates a new summary.
- ConstraintViolationSummary(TConstraintViolationSummary) - Constructor for class org.apache.accumulo.core.data.ConstraintViolationSummary
-
Creates a new summary from Thrift.
- consume() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
- consume() - Method in class org.apache.accumulo.core.iterators.SkippingIterator
- consume() - Method in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
- consumeBuffer(int) - Method in class org.apache.accumulo.core.rpc.FilterTransport
- contains(byte[]) - Method in class org.apache.accumulo.core.security.Authorizations
-
Checks whether this object contains the given authorization.
- contains(String) - Method in class org.apache.accumulo.core.security.Authorizations
-
Checks whether this object contains the given authorization.
- contains(ByteSequence) - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- contains(ByteSequence) - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- contains(ByteSequence) - Method in interface org.apache.accumulo.core.security.AuthorizationContainer
-
Checks whether this object contains the given authorization.
- contains(ByteSequence) - Method in class org.apache.accumulo.core.security.Authorizations
-
Checks whether this object contains the given authorization.
- contains(Key) - Method in class org.apache.accumulo.core.data.Range
-
Determines if the given key falls within this range.
- contains(Key) - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
- contains(BinaryComparable) - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- contains(BinaryComparable) - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- containsKey(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
- containsKey(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
- containsValue(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
- contextIterators(TaskAttemptContext, String) - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
Extracts Iterators settings from the context to be used by RecordReader.
- contextIterators(TaskAttemptContext, String) - Method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase.RecordReaderBase
- continueMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
- continueMultiScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueMultiScan
- continueMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- continueMultiScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- continueMultiScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- continueMultiScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- continueMultiScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- continueMultiScan_args(TabletClientService.continueMultiScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
-
Performs a deep copy on other.
- continueMultiScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- continueMultiScan_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueMultiScan_call
- continueMultiScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- continueMultiScan_result(MultiScanResult, NoSuchScanIDException, TSampleNotPresentException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- continueMultiScan_result(TabletClientService.continueMultiScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
-
Performs a deep copy on other.
- continueScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
- continueScan() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueScan
- continueScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- continueScan(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- continueScan(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- continueScan(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- continueScan_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- continueScan_args(TabletClientService.continueScan_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
-
Performs a deep copy on other.
- continueScan_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- continueScan_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueScan_call
- continueScan_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- continueScan_result(ScanResult, NoSuchScanIDException, NotServingTabletException, TooManyFilesException, TSampleNotPresentException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- continueScan_result(TabletClientService.continueScan_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
Performs a deep copy on other.
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.AuthConverter
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.MemoryConverter
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.PasswordConverter
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.TimeConverter
- convert(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.VisibilityConverter
- convert(String) - Method in class org.apache.accumulo.core.compaction.NullType
- convertClientConfig(Configuration) - Static method in class org.apache.accumulo.core.client.impl.ClientContext
-
A utility method for converting client configuration to a standard configuration object for use internally.
- copy(byte[]) - Method in class org.apache.accumulo.core.data.Value
-
Sets the byte data of this value.
- copy(Configuration) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- COPY_FILES - org.apache.accumulo.core.master.thrift.BulkImportState
- COPYONWRITE_ARRAYLIST - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for CopyOnWriteArrayList
- COPYONWRITE_ARRAYSET - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for CopyOnWriteArraySet
- copyPartialKey(Key, PartialKey) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Creates a copy of
key
, copying only the parts of the key specified inpart
. - CORE_PACKAGE_NAME - Static variable in class org.apache.accumulo.core.Constants
- COULD_NOT_APPLY - org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
- COULD_NOT_DESERIALIZE - org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
- count - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- COUNT - org.apache.accumulo.core.conf.PropertyType
- COUNT - org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
- CountingIterator - Class in org.apache.accumulo.core.iterators.system
- CountingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.system.CountingIterator
- CountSampler - Class in org.apache.accumulo.core.trace
-
This wrapper intended for internal Accumulo tracing makes creating a CountSampler easier.
- CountSampler(long) - Constructor for class org.apache.accumulo.core.trace.CountSampler
- cq - Variable in class org.apache.accumulo.core.data.thrift.TCondition
- CQ - org.apache.accumulo.core.data.thrift.TCondition._Fields
- create() - Static method in class org.apache.accumulo.core.client.ClientConfiguration
-
Initializes an empty configuration object to be further configured with other methods on the class.
- create(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Create an empty namespace with no initial configuration.
- create(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Create a table with no special configuration
- create(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
- create(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- create(String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Deprecated.since 1.7.0; use
TableOperations.create(String, NewTableConfiguration)
instead. - create(String, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Deprecated.
- create(String, boolean, TimeType) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Deprecated.since 1.7.0; use
TableOperations.create(String, NewTableConfiguration)
instead. - create(String, boolean, TimeType) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Deprecated.
- create(String, NewTableConfiguration) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
- create(String, NewTableConfiguration) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- create(String, SharedRateLimiterFactory.RateProvider) - Method in class org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory
-
Lookup the RateLimiter associated with the specified name, or create a new one for that name.
- create(SocketAddress, long) - Static method in class org.apache.accumulo.core.rpc.TTimeoutTransport
- create(HostAndPort, long) - Static method in class org.apache.accumulo.core.rpc.TTimeoutTransport
- create(Path, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
- create(T, String) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
- create(T, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
-
Create a Volume with the given FileSystem that writes to the default path
- CREATE - org.apache.accumulo.core.client.impl.thrift.TableOperation
- CREATE_NAMESPACE - org.apache.accumulo.core.security.SystemPermission
- CREATE_TABLE - org.apache.accumulo.core.security.NamespacePermission
- CREATE_TABLE - org.apache.accumulo.core.security.SystemPermission
- CREATE_USER - org.apache.accumulo.core.security.SystemPermission
- createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
-
Deprecated.since 1.5.0; Use
Connector.createBatchDeleter(String, Authorizations, int, BatchWriterConfig)
instead. - createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
Deprecated.
- createBatchDeleter(String, Authorizations, int, long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
- createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
- createBatchDeleter(String, Authorizations, int, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createBatchScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a BatchScanner connected to Accumulo.
- createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
- createBatchScanner(String, Authorizations, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.Connector
-
Deprecated.since 1.5.0; Use
Connector.createBatchWriter(String, BatchWriterConfig)
instead. - createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
Deprecated.
- createBatchWriter(String, long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a BatchWriter connected to Accumulo.
- createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
- createBatchWriter(String, BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createClient(TServiceClientFactory<T>, TTransport) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
-
Create a Thrift client using the given factory and transport
- createClientTransport(HostAndPort, int, SslConnectionParams, SaslConnectionParams) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
-
Create a TTransport for clients to the given address with the provided socket timeout and session-layer configuration
- createCompressionStream(OutputStream, Compressor, int) - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a ConditionalWriter connected to Accumulo.
- createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
- createConditionalWriter(String, ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createDecompressionStream(InputStream, Decompressor, int) - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- createDefaultFormatSupplier() - Static method in class org.apache.accumulo.core.util.format.DateFormatSupplier
-
Create a Supplier for
FormatterConfig.DefaultDateFormat
s - CreateEmpty - Class in org.apache.accumulo.core.file.rfile
-
Create an empty RFile for use in recovering from data loss where Accumulo still refers internally to a path.
- CreateEmpty() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty
- CreateEmpty.IsSupportedCompressionAlgorithm - Class in org.apache.accumulo.core.file.rfile
- CreateEmpty.NamedLikeRFile - Class in org.apache.accumulo.core.file.rfile
- createEntry(Configuration, String, char[]) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Create a CredentialEntry using the configured Providers.
- createEntryInProvider(Object, String, char[]) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Create a CredentialEntry with the give name and credential in the credentialProvider.
- createErrorEvent(int, String, Object, Throwable) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- createEvent(int, String, Object, boolean) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- createFilter(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
-
Deprecated.
- createHeap(int) - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
- createInstanceFromPropertyName(AccumuloConfiguration, Property, Class<T>, T) - Static method in enum org.apache.accumulo.core.conf.Property
-
Creates a new instance of a class specified in a configuration property.
- createInterpolator() - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Deprecated.since 1.9.0; will be removed in 2.0.0 to eliminate commons config leakage into Accumulo API
- createLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
- createLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
- createLocalUser(String, PasswordToken) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Create a user
- createLocalUser(String, PasswordToken) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- createLocalUser(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- createLocalUser(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- createLocalUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- createLocalUser_args(ClientService.createLocalUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
Performs a deep copy on other.
- createLocalUser_args(TInfo, TCredentials, String, ByteBuffer) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- createLocalUser_call(TInfo, TCredentials, String, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.createLocalUser_call
- createLocalUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- createLocalUser_result(ClientService.createLocalUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
-
Performs a deep copy on other.
- createLocalUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- createMetadataScanner(String, Range) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Create an IsolatedScanner over the given table, fetching the columns necessary to determine when a table has transitioned to online or offline.
- createMetaStore(String) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
- createMetaStore(String) - Method in interface org.apache.accumulo.core.file.FileSKVWriter
- createMetaStore(String) - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
- createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.Connector
-
Deprecated.since 1.5.0; Use
Connector.createMultiTableBatchWriter(BatchWriterConfig)
instead. - createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
-
Deprecated.
- createMultiTableBatchWriter(long, long, int) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a Multi-Table BatchWriter connected to Accumulo.
- createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
- createMultiTableBatchWriter(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createMutation(String, long) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
-
Creates the Mutation for the Order section for the given file and time
- createNamespace(String, String) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- createParamsObjectFromAccumuloConfiguration(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloInputFormat
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloMultiTableInputFormat
- createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloRowInputFormat
- createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.Connector
-
Factory method to create a Scanner connected to Accumulo.
- createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
- createScanner(String, Authorizations) - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- createSimpleFormatSupplier(String) - Static method in class org.apache.accumulo.core.util.format.DateFormatSupplier
-
Create a generator for SimpleDateFormats accepting a dateFormat
- createSimpleFormatSupplier(String, TimeZone) - Static method in class org.apache.accumulo.core.util.format.DateFormatSupplier
-
Create a generator for SimpleDateFormats accepting a dateFormat
- createTable(String, String, boolean, TimeType) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- createTable(String, String, boolean, TimeType, Map<String, String>) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- createTable(String, String, TimeType, Map<String, String>) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- createTableInstanceFromPropertyName(AccumuloConfiguration, Property, Class<T>, T) - Static method in enum org.apache.accumulo.core.conf.Property
-
Creates a new instance of a class specified in a configuration property.
- CreateToken - Class in org.apache.accumulo.core.util
- CreateToken() - Constructor for class org.apache.accumulo.core.util.CreateToken
- createTransport(HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
-
Create a transport that is not pooled
- createUser(String, byte[], Authorizations) - Method in interface org.apache.accumulo.core.client.admin.Se