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.
- ConfigurationDocGen - Class in org.apache.accumulo.core.conf
-
This class generates documentation to inform users of the available configuration properties in a presentable form.
- 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.SecurityOperations
-
Deprecated.since 1.5.0; use
SecurityOperations.createLocalUser(String, PasswordToken)
or the user management functions of your configured authenticator instead. - createUser(String, byte[], Authorizations) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
Deprecated.
- CREATION_DATE - org.apache.accumulo.core.security.thrift.TAuthenticationKey._Fields
- creationDate - Variable in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- CREDENTIAL_PROVIDER_PATH - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- CREDENTIAL_PROVIDERS_PROPERTY - Static variable in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
- CredentialProviderFactoryShim - Class in org.apache.accumulo.core.conf
-
Shim around Hadoop: tries to use the CredentialProviderFactory provided by hadoop-common, falling back to a copy inside accumulo-core.
- CredentialProviderFactoryShim() - Constructor for class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- CredentialProviderToken - Class in org.apache.accumulo.core.client.security.tokens
-
An
AuthenticationToken
backed by a Hadoop CredentialProvider. - CredentialProviderToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
- CredentialProviderToken(String, String) - Constructor for class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- credentials - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- credentials - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- credentials - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- credentials - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- credentials - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- credentials - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- credentials - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- Credentials - Class in org.apache.accumulo.core.client.impl
-
A wrapper for internal use.
- Credentials(String, AuthenticationToken) - Constructor for class org.apache.accumulo.core.client.impl.Credentials
-
Creates a new credentials object.
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
- CREDENTIALS - org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
- CREDENTIALS - org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
- CREDENTIALS - org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
- CREDENTIALS - org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
- CREDENTIALS - org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
- CREDENTIALS - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
- CRYPTO_BLOCK_STREAM_SIZE - org.apache.accumulo.core.conf.Property
- CRYPTO_CIPHER_ALGORITHM_NAME - org.apache.accumulo.core.conf.Property
- CRYPTO_CIPHER_KEY_LENGTH - org.apache.accumulo.core.conf.Property
- CRYPTO_CIPHER_SUITE - org.apache.accumulo.core.conf.Property
- CRYPTO_DEFAULT_KEY_STRATEGY_CIPHER_SUITE - org.apache.accumulo.core.conf.Property
- CRYPTO_DEFAULT_KEY_STRATEGY_HDFS_URI - org.apache.accumulo.core.conf.Property
- CRYPTO_DEFAULT_KEY_STRATEGY_KEY_LOCATION - org.apache.accumulo.core.conf.Property
- CRYPTO_MODULE_CLASS - org.apache.accumulo.core.conf.Property
- CRYPTO_OVERRIDE_KEY_STRATEGY_WITH_CONFIGURED_STRATEGY - org.apache.accumulo.core.conf.Property
- CRYPTO_PREFIX - org.apache.accumulo.core.conf.Property
- CRYPTO_SECRET_KEY_ENCRYPTION_STRATEGY_CLASS - org.apache.accumulo.core.conf.Property
- CRYPTO_SECURE_RNG - org.apache.accumulo.core.conf.Property
- CRYPTO_SECURE_RNG_PROVIDER - org.apache.accumulo.core.conf.Property
- CryptoModule - Interface in org.apache.accumulo.core.security.crypto
-
Classes that obey this interface may be used to provide encrypting and decrypting streams to the rest of Accumulo.
- CryptoModuleFactory - Class in org.apache.accumulo.core.security.crypto
-
This factory module exists to assist other classes in loading crypto modules.
- CryptoModuleFactory() - Constructor for class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
- CryptoModuleParameters - Class in org.apache.accumulo.core.security.crypto
-
This class defines several parameters needed by by a module providing cryptographic stream support in Accumulo.
- CryptoModuleParameters() - Constructor for class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
- CT - Static variable in class org.apache.accumulo.core.client.impl.Translators
- current - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
- CURRENT - org.apache.accumulo.core.client.impl.thrift.ConfigurationType
- CURRENT - org.apache.accumulo.core.gc.thrift.GCStatus._Fields
- CURRENT_LOG - org.apache.accumulo.core.gc.thrift.GCStatus._Fields
- currentDocID - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- currentK - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
The Key that should be returned to the client
- currentKey - Variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
- currentKey - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
The Key that is used to determine progress in the current InputSplit.
- CurrentLocationColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.CurrentLocationColumnFamily
- currentLog - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
- currentPartition - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- currentTrace() - Static method in class org.apache.accumulo.core.trace.Trace
-
Deprecated.since 1.7 -- it is better to save the span you create in a local variable and call its methods, rather than retrieving the current span
- currentTraceId() - Static method in class org.apache.accumulo.core.trace.Trace
-
Get the trace id of the current span.
- currentV - Variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
-
The Value that should be return to the client
- cv - Variable in class org.apache.accumulo.core.data.thrift.TCondition
- CV - org.apache.accumulo.core.data.thrift.TCondition._Fields
- cve - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- CVE - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
- CVST - Static variable in class org.apache.accumulo.core.client.impl.Translators
- CVSTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.CVSTranslator
D
- Daemon - Class in org.apache.accumulo.core.util
- Daemon() - Constructor for class org.apache.accumulo.core.util.Daemon
- Daemon(Runnable) - Constructor for class org.apache.accumulo.core.util.Daemon
- Daemon(Runnable, String) - Constructor for class org.apache.accumulo.core.util.Daemon
- Daemon(String) - Constructor for class org.apache.accumulo.core.util.Daemon
- data - Variable in class org.apache.accumulo.core.data.ArrayByteSequence
- data - Variable in class org.apache.accumulo.core.data.ComparableBytes
-
Deprecated.
- data - Variable in class org.apache.accumulo.core.data.impl.ComparableBytes
- data - Variable in class org.apache.accumulo.core.data.thrift.TMutation
- data - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- data - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- data(String, String) - Method in class org.apache.accumulo.core.trace.Span
- data(String, String) - Static method in class org.apache.accumulo.core.trace.Trace
-
Add data to the current span.
- DATA - org.apache.accumulo.core.data.thrift.TMutation._Fields
- DATA - org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
- DATA - org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
- DATA_CACHE_HITS - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- DATA_CACHE_REQUEST - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- dataCacheHits - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- dataCacheRequest - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- DataFileColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.DataFileColumnFamily
- DataFileValue - Class in org.apache.accumulo.core.metadata.schema
- DataFileValue(byte[]) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
- DataFileValue(long, long) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
- DataFileValue(long, long, long) - Constructor for class org.apache.accumulo.core.metadata.schema.DataFileValue
- DataoutputHasher - Class in org.apache.accumulo.core.sample.impl
- DataoutputHasher(Hasher) - Constructor for class org.apache.accumulo.core.sample.impl.DataoutputHasher
- DATE_FORMAT - Static variable in class org.apache.accumulo.core.util.format.DateStringFormatter
-
Deprecated.
- DateFormatSupplier - Class in org.apache.accumulo.core.util.format
-
DateFormatSupplier is a
ThreadLocal<DateFormat>
that will set the correct TimeZone when the object is retrieved byDateFormatSupplier.get()
. - DateFormatSupplier() - Constructor for class org.apache.accumulo.core.util.format.DateFormatSupplier
- DateFormatSupplier(TimeZone) - Constructor for class org.apache.accumulo.core.util.format.DateFormatSupplier
- DateLexicoder - Class in org.apache.accumulo.core.client.lexicoder
-
A lexicoder for date objects.
- DateLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.DateLexicoder
- DateStringFormatter - Class in org.apache.accumulo.core.util.format
-
Deprecated.
- DateStringFormatter() - Constructor for class org.apache.accumulo.core.util.format.DateStringFormatter
-
Deprecated.
- DateStringFormatter(TimeZone) - Constructor for class org.apache.accumulo.core.util.format.DateStringFormatter
-
Deprecated.
- DEAD_TABLET_SERVERS - org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
- DeadServer - Class in org.apache.accumulo.core.master.thrift
- DeadServer() - Constructor for class org.apache.accumulo.core.master.thrift.DeadServer
- DeadServer(String, long, String) - Constructor for class org.apache.accumulo.core.master.thrift.DeadServer
- DeadServer(DeadServer) - Constructor for class org.apache.accumulo.core.master.thrift.DeadServer
-
Performs a deep copy on other.
- DeadServer._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.
- deadTabletServers - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- debug - Variable in class org.apache.accumulo.core.cli.ClientOpts
- DebugIterator - Class in org.apache.accumulo.core.iterators
- DebugIterator() - Constructor for class org.apache.accumulo.core.iterators.DebugIterator
- DebugIterator(String, SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.DebugIterator
- decode(byte[]) - Static method in class org.apache.accumulo.core.client.impl.CompactionStrategyConfigUtil
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.AbstractEncoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.DateLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.FloatLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.ListLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.PairLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.StringLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.TextLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
- decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
- decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
- decode(byte[]) - Method in class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
- decode(byte[]) - Method in interface org.apache.accumulo.core.iterators.TypedValueCombiner.Encoder
- decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
- decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
- decode(byte[]) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
- decode(byte[], int) - Static method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
- decode(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.AbstractEncoder
-
Checks if the byte array is null, or if parameters exceed the bounds of the byte array, then calls
AbstractEncoder.decodeUnchecked(byte[], int, int)
. - decode(DataInput) - Static method in class org.apache.accumulo.core.client.impl.CompactionStrategyConfigUtil
- decodeBase64FileName(String) - Static method in class org.apache.accumulo.core.util.Encoding
- decodeBooleans(String) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- decodeColumnFamilies(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
- decodeColumnFamily(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
- decodeColumnFamily(Key, Value) - Static method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
-
Decode whole row/cf out of value.
- decodeColumns(String) - Static method in class org.apache.accumulo.core.iterators.conf.ColumnSet
- decodeColumns(String) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- decodeColumns(String, String) - Static method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
-
Deprecated.
- decodeIdentifier(String) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
-
Decode the encoded
TokenIdentifier
into bytes suitable to reconstitute the identifier. - decodeIteratorSettings(byte[]) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- decodePrevEndRow(Value) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- decodePrevEndRow(Value) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- decodeRow(Key, Value) - Static method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
- decodeStatic(byte[], int, int) - Static method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.AbstractEncoder
-
Decodes a byte array without checking if the offset and len exceed the bounds of the actual array.
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
-
If offset == 0 and len == data.length, returns data.
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.DateLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.FloatLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.ListLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.LongLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.PairLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.ReverseLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.StringLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.TextLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
- decodeUnchecked(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
- decompress(ByteBuffer) - Method in class org.apache.accumulo.core.client.impl.CompressedIterators
- decompress(List<TKeyValue>) - Static method in class org.apache.accumulo.core.data.Key
-
Decompresses a list of key/value pairs received from thrift.
- decrement(KT, long) - Method in class org.apache.accumulo.core.util.MapCounter
- decryptSecretKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.CachingHDFSSecretKeyEncryptionStrategy
- decryptSecretKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.NonCachingSecretKeyEncryptionStrategy
- decryptSecretKey(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.SecretKeyEncryptionStrategy
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- deepCopy() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- deepCopy() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- deepCopy() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TKey
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.TRange
- deepCopy() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- deepCopy() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- deepCopy() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- deepCopy() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- deepCopy() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.Compacting
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- deepCopy() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- deepCopy() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- deepCopy() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- deepCopy() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- deepCopy() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- deepCopy() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- deepCopy() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- deepCopy() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- deepCopy() - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- deepCopy() - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
- deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- deepCopy() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- deepCopy() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- deepCopy() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner.ScannerTranslator
-
Deprecated.
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Combiner
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DebugIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DevNull
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Filter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
- deepCopy(IteratorEnvironment) - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
-
Creates a deep copy of this iterator as though seek had not yet been called.
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.ColumnQualifierFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.CountingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.DeletingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.EmptyIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.MultiIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SampleIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.StatsIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.VisibilityFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
- deepCopy(IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
- DEFAULT - org.apache.accumulo.core.client.Durability
-
Use the durability as specified by the table or system configuration.
- DEFAULT - org.apache.accumulo.core.client.impl.thrift.ConfigurationType
- DEFAULT - org.apache.accumulo.core.tabletserver.thrift.TDurability
- DEFAULT_DOC_COLF - Static variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- DEFAULT_INDEX_COLF - Static variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- DEFAULT_NAMESPACE - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
- DEFAULT_NAMESPACE_ID - Static variable in class org.apache.accumulo.core.client.impl.Namespaces
- DEFAULT_SECURITY_ERROR - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- DEFAULT_SECURITY_ERROR - org.apache.accumulo.core.client.security.SecurityErrorCode
- DEFAULT_STRATEGY - Static variable in class org.apache.accumulo.core.client.impl.CompactionStrategyConfigUtil
- DEFAULT_TABLE_NAME - org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator.WriteOpts
- DEFAULT_TABLE_NAME - org.apache.accumulo.core.client.mapreduce.lib.util.OutputConfigurator.WriteOpts
-
Deprecated.
- DEFAULT_TABLET_LOCATION - Static variable in class org.apache.accumulo.core.Constants
-
Initial tablet directory name for the default tablet in all tables
- DEFAULT_VISIBILITY_CACHE_SIZE - Static variable in class org.apache.accumulo.core.Constants
- DefaultConfiguration - Class in org.apache.accumulo.core.conf
-
An
AccumuloConfiguration
that contains only default values for properties. - DefaultConfiguration() - Constructor for class org.apache.accumulo.core.conf.DefaultConfiguration
- DefaultCryptoModule - Class in org.apache.accumulo.core.security.crypto
-
This class implements the
CryptoModule
interface, defining how calling applications can receive encrypted input and output streams. - DefaultCryptoModule() - Constructor for class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
- DefaultCryptoModuleUtils - Class in org.apache.accumulo.core.security.crypto
- DefaultCryptoModuleUtils() - Constructor for class org.apache.accumulo.core.security.crypto.DefaultCryptoModuleUtils
- DefaultDateFormat() - Constructor for class org.apache.accumulo.core.util.format.FormatterConfig.DefaultDateFormat
- DefaultFormatter - Class in org.apache.accumulo.core.util.format
- DefaultFormatter() - Constructor for class org.apache.accumulo.core.util.format.DefaultFormatter
- DefaultKeySizeConstraint - Class in org.apache.accumulo.core.constraints
-
A constraints that limits the size of keys to 1mb.
- DefaultKeySizeConstraint() - Constructor for class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
- defaultNamespace() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Returns the name of the default namespace
- defaultNamespace() - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
- DefaultScanInterpreter - Class in org.apache.accumulo.core.util.interpret
- DefaultScanInterpreter() - Constructor for class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
- defaultVisibility - Variable in class org.apache.accumulo.core.iterators.system.VisibilityFilter
- DelegationToken - Interface in org.apache.accumulo.core.client.security.tokens
-
An
AuthenticationToken
that wraps a "Hadoop style" delegation token created by Accumulo. - DelegationTokenConfig - Class in org.apache.accumulo.core.client.admin
-
Configuration options for obtaining a delegation token created by
SecurityOperations.getDelegationToken(DelegationTokenConfig)
- DelegationTokenConfig() - Constructor for class org.apache.accumulo.core.client.admin.DelegationTokenConfig
- DelegationTokenConfigSerializer - Class in org.apache.accumulo.core.client.impl
-
Handles serialization of
DelegationTokenConfig
- DelegationTokenConfigSerializer() - Constructor for class org.apache.accumulo.core.client.impl.DelegationTokenConfigSerializer
- DelegationTokenImpl - Class in org.apache.accumulo.core.client.impl
- DelegationTokenImpl() - Constructor for class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- DelegationTokenImpl(byte[], AuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- DelegationTokenImpl(Instance, UserGroupInformation, AuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- DelegationTokenImpl(Token<? extends TokenIdentifier>, AuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- DelegationTokenStub - Class in org.apache.accumulo.core.client.mapreduce.impl
-
An internal stub class for passing DelegationToken information out of the Configuration back up to the appropriate implementation for mapreduce or mapred.
- DelegationTokenStub(String) - Constructor for class org.apache.accumulo.core.client.mapreduce.impl.DelegationTokenStub
- delete() - Method in interface org.apache.accumulo.core.client.BatchDeleter
-
Deletes the ranges specified by
BatchDeleter.setRanges(java.util.Collection<org.apache.accumulo.core.data.Range>)
. - delete() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchDeleter
- delete() - Method in class org.apache.accumulo.core.client.mock.MockBatchDeleter
-
Deprecated.
- delete(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Delete an empty namespace
- delete(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Delete a table
- delete(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
- delete(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- DELETE - org.apache.accumulo.core.client.impl.thrift.TableOperation
- DELETE_RANGE - org.apache.accumulo.core.client.impl.thrift.TableOperation
- DELETE_ROW_VALUE - Static variable in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
- deleted - Variable in class org.apache.accumulo.core.data.Key
- deleted - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- DELETED - org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
- DELETED - org.apache.accumulo.core.tabletserver.thrift.TUnloadTabletGoal
- deleteRows(String, Text, Text) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Delete rows between (start, end]
- deleteRows(String, Text, Text) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- DeletesSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
- DELETING - org.apache.accumulo.core.master.state.tables.TableState
- DeletingIterator - Class in org.apache.accumulo.core.iterators.system
- DeletingIterator() - Constructor for class org.apache.accumulo.core.iterators.system.DeletingIterator
- DeletingIterator(SortedKeyValueIterator<Key, Value>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.DeletingIterator
- DeletingIterator(DeletingIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.system.DeletingIterator
- DeprecationUtil - Class in org.apache.accumulo.core.util
-
A utility class for managing deprecated items.
- DeprecationUtil() - Constructor for class org.apache.accumulo.core.util.DeprecationUtil
- describeOptions() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- describeOptions() - Method in class org.apache.accumulo.core.iterators.Combiner
- describeOptions() - Method in class org.apache.accumulo.core.iterators.DebugIterator
- describeOptions() - Method in class org.apache.accumulo.core.iterators.Filter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
- describeOptions() - Method in class org.apache.accumulo.core.iterators.LongCombiner
- describeOptions() - Method in interface org.apache.accumulo.core.iterators.OptionDescriber
-
Gets an iterator options object that contains information needed to configure this iterator.
- describeOptions() - Method in class org.apache.accumulo.core.iterators.OrIterator
- describeOptions() - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
- describeOptions() - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.MaxCombiner
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.MinCombiner
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.ReqVisFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.SummingCombiner
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
- describeOptions() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
- description - Variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- description - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
- DESCRIPTION - org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
- deserialize(byte[], int, int, T) - Method in class org.apache.accumulo.core.util.ThriftMessageUtil
-
Deserializes a message into the provided
instance
fromserialized
- deserialize(byte[], T) - Method in class org.apache.accumulo.core.util.ThriftMessageUtil
-
Assumes the entire contents of the byte array compose the serialized
instance
- deserialize(Class<T>, byte[]) - Static method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
-
A convenience method to create tokens from serialized bytes, created by
AuthenticationToken.AuthenticationTokenSerializer.serialize(AuthenticationToken)
- deserialize(String) - Static method in class org.apache.accumulo.core.client.ClientConfiguration
- deserialize(String) - Static method in class org.apache.accumulo.core.client.impl.Credentials
-
Converts the serialized form to an instance of
Credentials
. - deserialize(String, byte[]) - Static method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
-
An alternate version of
AuthenticationToken.AuthenticationTokenSerializer.deserialize(Class, byte[])
that accepts a token class name rather than a token class. - deserialize(TDelegationTokenConfig) - Static method in class org.apache.accumulo.core.client.impl.DelegationTokenConfigSerializer
-
Deserialize the Thrift delegation token config into the non-thrift variant
- deserializeFetchedColumns(Collection<String>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
- deserializeFetchedColumns(Collection<String>) - 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.
- destroy() - Method in class org.apache.accumulo.core.client.mapreduce.impl.DelegationTokenStub
- destroy() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
- destroy() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
- destroy() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
- destroy() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
- DevNull - Class in org.apache.accumulo.core.iterators
-
An iterator that is useful testing...
- DevNull() - Constructor for class org.apache.accumulo.core.iterators.DevNull
- DIGEST_MD5 - org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
- DIGEST_MD5 - Static variable in class org.apache.accumulo.core.rpc.ThriftUtil
- DIRECTORY_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
-
Holds the location of the tablet in the DFS file system
- disable() - Static method in class org.apache.accumulo.core.trace.DistributedTrace
-
Disable tracing by closing SpanReceivers for the current process.
- disableIsolation() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
- disableIsolation() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
- disableIsolation() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
- disableIsolation() - Method in class org.apache.accumulo.core.client.IsolatedScanner
- disableIsolation() - Method in class org.apache.accumulo.core.client.mock.MockScanner
-
Deprecated.
- disableIsolation() - Method in interface org.apache.accumulo.core.client.Scanner
-
Disables row isolation.
- DiscardCloseOutputStream - Class in org.apache.accumulo.core.security.crypto
- DiscardCloseOutputStream(OutputStream) - Constructor for class org.apache.accumulo.core.security.crypto.DiscardCloseOutputStream
- DiskUsage - Class in org.apache.accumulo.core.client.admin
- DiskUsage(SortedSet<String>, Long) - Constructor for class org.apache.accumulo.core.client.admin.DiskUsage
- DistributedCacheHelper - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
- DistributedCacheHelper() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
- DistributedTrace - Class in org.apache.accumulo.core.trace
-
Utility class to enable tracing for Accumulo server processes.
- DistributedTrace() - Constructor for class org.apache.accumulo.core.trace.DistributedTrace
- docSource - Variable in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- doLookup(ClientContext, String, Map<KeyExtent, List<Range>>, Map<KeyExtent, List<Range>>, Map<KeyExtent, List<Range>>, TabletServerBatchReaderIterator.ResultReceiver, List<Column>, ScannerOptions, Authorizations) - Static method in class org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator
- doNotLimitShowLength() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
- DOSArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
- DoubleLexicoder - Class in org.apache.accumulo.core.client.lexicoder
-
A lexicoder for preserving the native Java sort order of Double values.
- DoubleLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
- drain(String) - Method in interface org.apache.accumulo.core.client.admin.ReplicationOperations
-
Waits for a table to be fully replicated, given the state of files pending replication for the provided table at the point in time which this method is invoked.
- drain(String) - Method in class org.apache.accumulo.core.client.impl.ReplicationOperationsImpl
- drain(String, Set<String>) - Method in interface org.apache.accumulo.core.client.admin.ReplicationOperations
-
Given the provided set of files that are pending replication for a table, wait for those files to be fully replicated to all configured peers.
- drain(String, Set<String>) - Method in class org.apache.accumulo.core.client.impl.ReplicationOperationsImpl
- drainReplicationTable() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.drainReplicationTable
- drainReplicationTable() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.drainReplicationTable
- drainReplicationTable(TInfo, TCredentials, String, Set<String>) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
- drainReplicationTable(TInfo, TCredentials, String, Set<String>) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
- drainReplicationTable(TInfo, TCredentials, String, Set<String>, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
- drainReplicationTable(TInfo, TCredentials, String, Set<String>, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
- drainReplicationTable_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- drainReplicationTable_args(MasterClientService.drainReplicationTable_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
-
Performs a deep copy on other.
- drainReplicationTable_args(TInfo, TCredentials, String, Set<String>) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- drainReplicationTable_call(TInfo, TCredentials, String, Set<String>, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.drainReplicationTable_call
- drainReplicationTable_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- drainReplicationTable_result(boolean) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- drainReplicationTable_result(MasterClientService.drainReplicationTable_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
-
Performs a deep copy on other.
- DROP_NAMESPACE - org.apache.accumulo.core.security.NamespacePermission
- DROP_NAMESPACE - org.apache.accumulo.core.security.SystemPermission
- DROP_TABLE - org.apache.accumulo.core.security.NamespacePermission
- DROP_TABLE - org.apache.accumulo.core.security.SystemPermission
- DROP_TABLE - org.apache.accumulo.core.security.TablePermission
- DROP_USER - org.apache.accumulo.core.security.SystemPermission
- dropLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
- dropLocalUser() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
- dropLocalUser(String) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Delete a user
- dropLocalUser(String) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- dropLocalUser(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- dropLocalUser(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- dropLocalUser(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- dropLocalUser(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- dropLocalUser_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- dropLocalUser_args(ClientService.dropLocalUser_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
Performs a deep copy on other.
- dropLocalUser_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- dropLocalUser_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.dropLocalUser_call
- dropLocalUser_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- dropLocalUser_result(ClientService.dropLocalUser_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
-
Performs a deep copy on other.
- dropLocalUser_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- droppingOldTimestamp(long) - Method in class org.apache.accumulo.core.data.Mutation
- dropUser(String) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Deprecated.since 1.5.0; use
SecurityOperations.dropUser(String)
or the user management functions of your configured authenticator instead. - dropUser(String) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
Deprecated.
- duplicateReads() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- durability - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- durability - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- durability - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- Durability - Enum in org.apache.accumulo.core.client
-
The value for the durability of a BatchWriter or ConditionalWriter.
- DURABILITY - org.apache.accumulo.core.conf.PropertyType
- DURABILITY - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
- DURABILITY - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
- DURABILITY - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
- DurabilityImpl - Class in org.apache.accumulo.core.client.impl
- DurabilityImpl() - Constructor for class org.apache.accumulo.core.client.impl.DurabilityImpl
- Duration - Class in org.apache.accumulo.core.util
- Duration() - Constructor for class org.apache.accumulo.core.util.Duration
- DynamicBloomFilter - Class in org.apache.accumulo.core.bloomfilter
-
Implements a dynamic Bloom filter, as defined in the INFOCOM 2006 paper.
- DynamicBloomFilter() - Constructor for class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
-
Zero-args constructor for the serialization.
- DynamicBloomFilter(int, int, int, int) - Constructor for class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
-
Constructor.
E
- e - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- e - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- e - Variable in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- E - org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
- E - org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
- E - org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
- edits - Variable in class org.apache.accumulo.core.replication.thrift.WalEdits
- EDITS - org.apache.accumulo.core.replication.thrift.WalEdits._Fields
- elapsed - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- ELAPSED - org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
- EMPTY - org.apache.accumulo.core.security.ColumnVisibility.NodeType
- EMPTY - Static variable in class org.apache.accumulo.core.security.Authorizations
-
An empty set of authorizations.
- EMPTY - Static variable in class org.apache.accumulo.core.security.ColumnVisibility.Node
-
An empty list of nodes.
- EMPTY_CF_SET - Static variable in class org.apache.accumulo.core.util.LocalityGroupUtil
- EMPTY_ITERATOR - Static variable in class org.apache.accumulo.core.iterators.system.EmptyIterator
- EmptyIterator - Class in org.apache.accumulo.core.iterators.system
- EmptyIterator() - Constructor for class org.apache.accumulo.core.iterators.system.EmptyIterator
- enable() - Static method in class org.apache.accumulo.core.trace.DistributedTrace
-
Enable tracing by setting up SpanReceivers for the current process.
- enable(String) - Static method in class org.apache.accumulo.core.trace.DistributedTrace
-
Enable tracing by setting up SpanReceivers for the current process.
- enable(String, String) - Static method in class org.apache.accumulo.core.trace.DistributedTrace
-
Enable tracing by setting up SpanReceivers for the current process.
- enable(String, String, ClientConfiguration) - Static method in class org.apache.accumulo.core.trace.DistributedTrace
-
Enable tracing by setting up SpanReceivers for the current process.
- enable(String, String, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.trace.DistributedTrace
-
Enable tracing by setting up SpanReceivers for the current process.
- enable(Instance, ZooReader, String, String) - Static method in class org.apache.accumulo.core.trace.DistributedTrace
-
Deprecated.since 1.7, use
DistributedTrace.enable(String, String, org.apache.accumulo.core.client.ClientConfiguration)
instead - ENABLE_EVICTION - org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.Options
- ENABLE_LOCKS - org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.Options
- enableIsolation() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
- enableIsolation() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
- enableIsolation() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
- enableIsolation() - Method in class org.apache.accumulo.core.client.IsolatedScanner
- enableIsolation() - Method in class org.apache.accumulo.core.client.mock.MockScanner
-
Deprecated.
- enableIsolation() - Method in interface org.apache.accumulo.core.client.Scanner
-
Enables row isolation.
- enableSampling(SamplerConfiguration) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
-
Enable building a sample data set on the new table using the given sampler configuration.
- enableYielding(YieldCallback<K>) - Method in interface org.apache.accumulo.core.iterators.YieldingKeyValueIterator
-
Allows implementations to preempt further iteration of this iterator in the current RPC.
- enableYielding(YieldCallback<Key>) - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
- encode() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- encode(byte[]) - Method in class org.apache.accumulo.core.client.lexicoder.BytesLexicoder
- encode(DataOutput, CompactionStrategyConfig) - Static method in class org.apache.accumulo.core.client.impl.CompactionStrategyConfigUtil
- encode(Double) - Method in class org.apache.accumulo.core.client.lexicoder.DoubleLexicoder
- encode(Float) - Method in class org.apache.accumulo.core.client.lexicoder.FloatLexicoder
- encode(Integer) - Method in class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
- encode(Integer) - Method in class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
- encode(Long) - Method in class org.apache.accumulo.core.client.lexicoder.LongLexicoder
- encode(Long) - Method in class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
- encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
- encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
- encode(Long) - Method in class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
- encode(String) - Method in class org.apache.accumulo.core.client.lexicoder.StringLexicoder
- encode(BigDecimal) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalEncoder
- encode(BigInteger) - Method in class org.apache.accumulo.core.client.lexicoder.BigIntegerLexicoder
- encode(Date) - Method in class org.apache.accumulo.core.client.lexicoder.DateLexicoder
- encode(List<Long>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
- encode(List<LT>) - Method in class org.apache.accumulo.core.client.lexicoder.ListLexicoder
- encode(List<V>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
- encode(UUID) - Method in class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
- encode(CompactionStrategyConfig) - Static method in class org.apache.accumulo.core.client.impl.CompactionStrategyConfigUtil
- encode(ComparablePair<A, B>) - Method in class org.apache.accumulo.core.client.lexicoder.PairLexicoder
- encode(Text) - Method in class org.apache.accumulo.core.client.lexicoder.TextLexicoder
- encode(T) - Method in class org.apache.accumulo.core.client.lexicoder.ReverseLexicoder
- encode(V) - Method in interface org.apache.accumulo.core.iterators.TypedValueCombiner.Encoder
- encodeAsBase64FileName(Text) - Static method in class org.apache.accumulo.core.util.Encoding
- encodeAsString() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- encodeAsValue() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- encodeBooleans(boolean[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- encodeColumnFamilies(Set<Text>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
- encodeColumnFamily(List<Key>, List<Value>) - Static method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
-
Encode row/cf.
- encodeColumnFamily(ByteSequence) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
- encodeColumns() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
-
Deprecated.
- encodeColumns(Text[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- encodeColumns(Text, Text) - Static method in class org.apache.accumulo.core.iterators.conf.ColumnSet
- encodeColumns(Text, Text) - Static method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
-
Deprecated.
- encodeIdentifier(byte[]) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
-
Encode the serialized
TokenIdentifier
into aString
. - encodeIteratorSettings(List<IteratorSetting>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- encodeIteratorSettings(IteratorConfig) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- encodePassword(byte[]) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
-
Encode the token password into a character array.
- encodePrevEndRow(Text) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- encodePrevEndRow(Text) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- Encoder<T> - Interface in org.apache.accumulo.core.client.lexicoder
-
An encoder represents a typed object that can be encoded/decoded to/from a byte array.
- encodeRow(List<Key>, List<Value>) - Static method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
- Encoding - Class in org.apache.accumulo.core.util
- Encoding() - Constructor for class org.apache.accumulo.core.util.Encoding
- ENCODING - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
- ENCODING_DEFAULT - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
- encryptSecretKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.CachingHDFSSecretKeyEncryptionStrategy
- encryptSecretKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.NonCachingSecretKeyEncryptionStrategy
- encryptSecretKey(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.SecretKeyEncryptionStrategy
- END - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
- END_BOUND - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
- END_INCL - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
- END_INCLUSIVE - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
- END_ROW - org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
- END_ROW - org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
- END_ROW - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
- END_ROW - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
- endRow - Variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
- endRow - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- endRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- endRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- entries - Variable in class org.apache.accumulo.core.data.thrift.TMutation
- ENTRIES - org.apache.accumulo.core.data.thrift.TMutation._Fields
- ENTRIES_READ - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
- ENTRIES_WRITTEN - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
- entriesRead - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- entriesWritten - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- entrySet() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
- enumToConfKey(Class<?>, Enum<?>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Provides a configuration key for a given feature enum, prefixed by the implementingClass
- enumToConfKey(Class<?>, Enum<?>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- enumToConfKey(Enum<?>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Provides a configuration key for a given feature enum.
- equals(Object) - Method in class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
- equals(Object) - Method in class org.apache.accumulo.core.client.admin.DelegationTokenConfig
- equals(Object) - Method in class org.apache.accumulo.core.client.admin.DiskUsage
- equals(Object) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.Credentials
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- equals(Object) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- equals(Object) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- equals(Object) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
- equals(Object) - Method in class org.apache.accumulo.core.client.IteratorSetting
- equals(Object) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
- equals(Object) - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
- equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
- equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
- equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
- equals(Object) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
- equals(Object) - Method in class org.apache.accumulo.core.data.ByteSequence
- equals(Object) - Method in class org.apache.accumulo.core.data.Column
- equals(Object) - Method in class org.apache.accumulo.core.data.ColumnUpdate
- equals(Object) - Method in class org.apache.accumulo.core.data.Condition
- equals(Object) - Method in class org.apache.accumulo.core.data.ConditionalMutation
- equals(Object) - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- equals(Object) - Method in class org.apache.accumulo.core.data.impl.TabletIdImpl
- equals(Object) - Method in class org.apache.accumulo.core.data.Key
- equals(Object) - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- equals(Object) - Method in class org.apache.accumulo.core.data.Mutation
- equals(Object) - Method in class org.apache.accumulo.core.data.Range
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TColumn
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TCondition
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TKey
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TMutation
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.TRange
- equals(Object) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- equals(Object) - Method in class org.apache.accumulo.core.data.Value
- equals(Object) - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- equals(Object) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
- equals(Object) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
- equals(Object) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- equals(Object) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- equals(Object) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- equals(Object) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- equals(Object) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- equals(Object) - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColFamHashKey
- equals(Object) - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColHashKey
- equals(Object) - Method in class org.apache.accumulo.core.iterators.OrIterator.TermSource
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.Compacting
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- equals(Object) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- equals(Object) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- equals(Object) - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- equals(Object) - Method in class org.apache.accumulo.core.replication.ReplicationTarget
- equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- equals(Object) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- equals(Object) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- equals(Object) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- equals(Object) - Method in class org.apache.accumulo.core.rpc.SaslClientDigestCallbackHandler
- equals(Object) - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
- equals(Object) - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- equals(Object) - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
- equals(Object) - Method in class org.apache.accumulo.core.security.Authorizations
- equals(Object) - Method in class org.apache.accumulo.core.security.ColumnVisibility
- equals(Object) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- equals(Object) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- equals(Object) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- equals(Object) - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- equals(Object) - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
- equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- equals(Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- equals(Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- equals(Object) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- equals(Object) - Method in class org.apache.accumulo.core.util.ColumnFQ
- equals(Object) - Method in class org.apache.accumulo.core.util.HostAndPort
- equals(Object) - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
- equals(Object) - Method in class org.apache.accumulo.core.util.Pair
- equals(Object) - Method in class org.apache.accumulo.core.util.ServerServices
- equals(Object) - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
- equals(Object) - Method in class org.apache.accumulo.core.volume.VolumeImpl
- equals(ClientService.authenticate_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- equals(ClientService.authenticate_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- equals(ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- equals(ClientService.authenticateUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- equals(ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- equals(ClientService.bulkImportFiles_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- equals(ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- equals(ClientService.changeAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- equals(ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- equals(ClientService.changeLocalUserPassword_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- equals(ClientService.checkClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- equals(ClientService.checkClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- equals(ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- equals(ClientService.checkNamespaceClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- equals(ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- equals(ClientService.checkTableClass_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- equals(ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- equals(ClientService.createLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- equals(ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- equals(ClientService.dropLocalUser_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- equals(ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- equals(ClientService.getConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- equals(ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- equals(ClientService.getDiskUsage_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- equals(ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- equals(ClientService.getInstanceId_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- equals(ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- equals(ClientService.getNamespaceConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- equals(ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- equals(ClientService.getRootTabletLocation_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- equals(ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- equals(ClientService.getTableConfiguration_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- equals(ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- equals(ClientService.getUserAuthorizations_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- equals(ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- equals(ClientService.getZooKeepers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- equals(ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- equals(ClientService.grantNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- equals(ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- equals(ClientService.grantSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- equals(ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- equals(ClientService.grantTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- equals(ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- equals(ClientService.hasNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- equals(ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- equals(ClientService.hasSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- equals(ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- equals(ClientService.hasTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- equals(ClientService.isActive_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- equals(ClientService.isActive_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- equals(ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- equals(ClientService.listLocalUsers_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- equals(ClientService.ping_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- equals(ClientService.ping_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- equals(ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- equals(ClientService.revokeNamespacePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- equals(ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- equals(ClientService.revokeSystemPermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- equals(ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- equals(ClientService.revokeTablePermission_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- equals(TDiskUsage) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- equals(ThriftSecurityException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- equals(ThriftTableOperationException) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- equals(ThriftTest.fails_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- equals(ThriftTest.fails_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- equals(ThriftTest.success_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- equals(ThriftTest.success_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- equals(ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- equals(ThriftTest.throwsError_result) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- equals(Column) - Method in class org.apache.accumulo.core.data.Column
-
Checks if this column equals another.
- equals(Key, PartialKey) - Method in class org.apache.accumulo.core.data.Key
-
Compares part of a key.
- equals(Mutation) - Method in class org.apache.accumulo.core.data.Mutation
-
Checks if this mutation equals another.
- equals(Mutation) - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
- equals(Range) - Method in class org.apache.accumulo.core.data.Range
-
Determines if this range equals another.
- equals(InitialMultiScan) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- equals(InitialScan) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- equals(IterInfo) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- equals(MapFileInfo) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- equals(MultiScanResult) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- equals(ScanResult) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- equals(TCMResult) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- equals(TColumn) - Method in class org.apache.accumulo.core.data.thrift.TColumn
- equals(TCondition) - Method in class org.apache.accumulo.core.data.thrift.TCondition
- equals(TConditionalMutation) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- equals(TConditionalSession) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- equals(TConstraintViolationSummary) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- equals(TKey) - Method in class org.apache.accumulo.core.data.thrift.TKey
- equals(TKeyExtent) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- equals(TKeyValue) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- equals(TMutation) - Method in class org.apache.accumulo.core.data.thrift.TMutation
- equals(TRange) - Method in class org.apache.accumulo.core.data.thrift.TRange
- equals(UpdateErrors) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- equals(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- equals(GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- equals(GCMonitorService.getStatus_result) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- equals(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- equals(ColumnUtil.ColFamHashKey) - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColFamHashKey
- equals(ColumnUtil.ColHashKey) - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColHashKey
- equals(BulkImportStatus) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- equals(Compacting) - Method in class org.apache.accumulo.core.master.thrift.Compacting
- equals(DeadServer) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- equals(FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- equals(FateService.beginFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- equals(FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- equals(FateService.executeFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- equals(FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- equals(FateService.finishFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- equals(FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- equals(FateService.waitForFateOperation_result) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- equals(MasterClientService.drainReplicationTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- equals(MasterClientService.drainReplicationTable_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- equals(MasterClientService.getActiveTservers_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- equals(MasterClientService.getActiveTservers_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- equals(MasterClientService.getDelegationToken_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- equals(MasterClientService.getDelegationToken_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- equals(MasterClientService.getMasterStats_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- equals(MasterClientService.getMasterStats_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- equals(MasterClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- equals(MasterClientService.initiateFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- equals(MasterClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- equals(MasterClientService.removeNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- equals(MasterClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- equals(MasterClientService.removeSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- equals(MasterClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- equals(MasterClientService.removeTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- equals(MasterClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- equals(MasterClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- equals(MasterClientService.setMasterGoalState_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- equals(MasterClientService.setMasterGoalState_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- equals(MasterClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- equals(MasterClientService.setNamespaceProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- equals(MasterClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- equals(MasterClientService.setSystemProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- equals(MasterClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- equals(MasterClientService.setTableProperty_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- equals(MasterClientService.shutdown_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- equals(MasterClientService.shutdown_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- equals(MasterClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- equals(MasterClientService.shutdownTabletServer_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- equals(MasterClientService.waitForBalance_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- equals(MasterClientService.waitForBalance_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
- equals(MasterClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- equals(MasterClientService.waitForFlush_result) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- equals(MasterMonitorInfo) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- equals(RecoveryException) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- equals(RecoveryStatus) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- equals(TableInfo) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- equals(TabletServerStatus) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- equals(TabletSplit) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- equals(KeyValues) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- equals(RemoteReplicationException) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- equals(ReplicationCoordinator.getServicerAddress_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- equals(ReplicationCoordinator.getServicerAddress_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- equals(ReplicationCoordinatorException) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- equals(ReplicationServicer.replicateKeyValues_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- equals(ReplicationServicer.replicateKeyValues_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- equals(ReplicationServicer.replicateLog_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- equals(ReplicationServicer.replicateLog_result) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- equals(WalEdits) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- equals(ColumnVisibility) - Method in class org.apache.accumulo.core.security.ColumnVisibility
-
Compares two ColumnVisibilities for string equivalence, not as a meaningful comparison of terms and conditions.
- equals(TAuthenticationKey) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- equals(TAuthenticationTokenIdentifier) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- equals(TCredentials) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- equals(TDelegationToken) - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- equals(TDelegationTokenConfig) - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- equals(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- equals(ActiveCompaction) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- equals(ActiveScan) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- equals(ConstraintViolationException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- equals(IteratorConfig) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- equals(NoSuchScanIDException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
- equals(NotServingTabletException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- equals(TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- equals(TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- equals(TabletClientService.bulkImport_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- equals(TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- equals(TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- equals(TabletClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- equals(TabletClientService.closeMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- equals(TabletClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- equals(TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- equals(TabletClientService.closeUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- equals(TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- equals(TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- equals(TabletClientService.conditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- equals(TabletClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- equals(TabletClientService.continueMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- equals(TabletClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- equals(TabletClientService.continueScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- equals(TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- equals(TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- equals(TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- equals(TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- equals(TabletClientService.getActiveCompactions_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- equals(TabletClientService.getActiveLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- equals(TabletClientService.getActiveLogs_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- equals(TabletClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- equals(TabletClientService.getActiveScans_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- equals(TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- equals(TabletClientService.getHistoricalStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- equals(TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- equals(TabletClientService.getTabletServerStatus_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- equals(TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- equals(TabletClientService.getTabletStats_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- equals(TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- equals(TabletClientService.halt_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- equals(TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- equals(TabletClientService.invalidateConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- equals(TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- equals(TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- equals(TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- equals(TabletClientService.splitTablet_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- equals(TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- equals(TabletClientService.startConditionalUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- equals(TabletClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- equals(TabletClientService.startMultiScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- equals(TabletClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- equals(TabletClientService.startScan_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- equals(TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- equals(TabletClientService.startUpdate_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- equals(TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- equals(TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- equals(TabletClientService.update_result) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- equals(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- equals(TIteratorSetting) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- equals(TooManyFilesException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- equals(TSampleNotPresentException) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- equals(TSamplerConfiguration) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- equals(TInfo) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- equals(Text, Text) - Method in class org.apache.accumulo.core.util.ColumnFQ
- ERROR_DIR - org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
- errorDir - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- errors - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- ERRORS - org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
- escape(byte[]) - Static method in class org.apache.accumulo.core.client.lexicoder.impl.ByteUtils
-
Escapes 0x00 with 0x01 0x01 and 0x01 with 0x01 0x02
- escape(byte[], boolean) - Static method in class org.apache.accumulo.core.security.VisibilityEvaluator
-
Properly escapes an authorization string.
- ESTIMATED_SIZE - org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
- estimatedMemoryUsed() - Method in class org.apache.accumulo.core.data.Mutation
-
Gets an estimate of the amount of memory used by this mutation.
- estimatedSize - Variable in class org.apache.accumulo.core.data.thrift.MapFileInfo
- evaluate(ColumnVisibility) - Method in class org.apache.accumulo.core.security.VisibilityEvaluator
-
Evaluates the given column visibility against the authorizations provided to this evaluator.
- evict() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- evictBlock(CachedBlock) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
- evicted() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- evictedPerEviction() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- ex - Variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- EX - org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
- exact(CharSequence) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row.
- exact(CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row and column family.
- exact(CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row, column family, and column qualifier.
- exact(CharSequence, CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row, column family, column qualifier, and column visibility.
- exact(CharSequence, CharSequence, CharSequence, CharSequence, long) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row, column family, column qualifier, column visibility, and timestamp.
- exact(Text) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row.
- exact(Text, Text) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row and column family.
- exact(Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row, column family, and column qualifier.
- exact(Text, Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row, column family, column qualifier, and column visibility.
- exact(Text, Text, Text, Text, long) - Static method in class org.apache.accumulo.core.data.Range
-
Creates a range that covers an exact row, column family, column qualifier, column visibility, and timestamp.
- execute() - Method in class org.apache.accumulo.core.file.FileOperations.GetFileSizeOperation
-
Return the size of the file.
- execute() - Method in interface org.apache.accumulo.core.file.FileOperations.GetFileSizeOperationBuilder
-
Return the size of the file.
- execute(C) - Method in interface org.apache.accumulo.core.client.impl.ClientExecReturn
- execute(String[]) - Method in class org.apache.accumulo.core.file.rfile.PrintInfo
- execute(String[]) - Method in class org.apache.accumulo.core.util.Classpath
- execute(String[]) - Method in class org.apache.accumulo.core.util.CreateToken
- execute(String[]) - Method in class org.apache.accumulo.core.util.Help
- execute(String[]) - Method in class org.apache.accumulo.core.util.Jar
- execute(String[]) - Method in class org.apache.accumulo.core.util.Version
- execute(ClientContext, ClientExecReturn<T, ClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- execute(ClientContext, ClientExecReturn<T, MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
- execute(ClientContext, TServiceClientFactory<CT>, ClientExecReturn<RT, CT>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- execute(T) - Method in interface org.apache.accumulo.core.client.impl.ClientExec
- executeCoordinatorWithReturn(ClientContext, ClientExecReturn<T, ReplicationCoordinator.Client>) - Static method in class org.apache.accumulo.core.client.impl.ReplicationClient
- executeFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
- executeFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor.executeFateOperation
- executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
- executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Method in interface org.apache.accumulo.core.master.thrift.FateService.Iface
- executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient
- executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.FateService.AsyncIface
- executeFateOperation_args() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- executeFateOperation_args(FateService.executeFateOperation_args) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Performs a deep copy on other.
- executeFateOperation_args(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- executeFateOperation_call(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.executeFateOperation_call
- executeFateOperation_result() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- executeFateOperation_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- executeFateOperation_result(FateService.executeFateOperation_result) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
-
Performs a deep copy on other.
- executeGeneric(ClientContext, ClientExec<MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
- executeNamespace(ClientContext, ClientExec<MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
- executeRaw(ClientContext, ClientExecReturn<T, ClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- executeRaw(ClientContext, TServiceClientFactory<CT>, ClientExecReturn<RT, CT>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- executeRawVoid(ClientContext, ClientExec<ClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- executeServicerWithReturn(ClientContext, HostAndPort, ClientExecReturn<T, ReplicationServicer.Client>, long) - Static method in class org.apache.accumulo.core.client.impl.ReplicationClient
- executeTable(ClientContext, ClientExec<MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
- executeVoid(ClientContext, ClientExec<ClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- executeVoid(ClientContext, ClientExec<MasterClientService.Client>) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
- exists(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
A method to check if a namespace exists in Accumulo.
- exists(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
A method to check if a table exists in Accumulo.
- exists(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
- exists(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- exists(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
- exists(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
- EXISTS - org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
- exit(int) - Method in class org.apache.accumulo.core.cli.Help
- exitWithError(String, int) - Method in class org.apache.accumulo.core.cli.Help
- EXPIRATION_DATE - org.apache.accumulo.core.security.thrift.TAuthenticationKey._Fields
- EXPIRATION_DATE - org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
- expirationDate - Variable in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- expirationDate - Variable in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- expireAllObservers() - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
-
Expires all observers.
- EXPORT - org.apache.accumulo.core.client.impl.thrift.TableOperation
- EXPORT_FILE - Static variable in class org.apache.accumulo.core.Constants
- EXPORT_INFO_FILE - Static variable in class org.apache.accumulo.core.Constants
- EXPORT_METADATA_FILE - Static variable in class org.apache.accumulo.core.Constants
- EXPORT_TABLE_CONFIG_FILE - Static variable in class org.apache.accumulo.core.Constants
- exportTable(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Exports a table.
- exportTable(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- EXTENSION - Static variable in class org.apache.accumulo.core.file.rfile.RFile
- extent - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- extent - Variable in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- extent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- extent - Variable in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- extent - Variable in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
- EXTENT - org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
- EXTENT - Static variable in class org.apache.accumulo.core.metadata.RootTable
F
- Factory() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Client.Factory
- Factory() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client.Factory
- Factory() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
- Factory() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Client.Factory
- Factory() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Client.Factory
- Factory() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client.Factory
- Factory() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Client.Factory
- Factory() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient.Factory
- Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.Factory
- fail - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- FAIL - org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
- FAILED_EXTENTS - org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
- failedExtents - Variable in class org.apache.accumulo.core.data.thrift.UpdateErrors
- fails() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
- fails() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.fails
- fails() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client
- fails() - Method in interface org.apache.accumulo.core.client.impl.thrift.ThriftTest.Iface
- fails(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient
- fails(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncIface
- fails_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- fails_args(ThriftTest.fails_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
-
Performs a deep copy on other.
- fails_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.fails_call
- fails_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- fails_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- fails_result(ThriftTest.fails_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
-
Performs a deep copy on other.
- failures - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
- FAILURES - org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
- families(Collection<Column>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
-
Create a set of families to be passed into the SortedKeyValueIterator seek call from a supplied set of columns.
- FamilyIntersectingIterator - Class in org.apache.accumulo.core.iterators
-
Deprecated.since 1.4, replaced by
IndexedDocIterator
- FamilyIntersectingIterator() - Constructor for class org.apache.accumulo.core.iterators.FamilyIntersectingIterator
-
Deprecated.
- FastFormat - Class in org.apache.accumulo.core.util
- FastFormat() - Constructor for class org.apache.accumulo.core.util.FastFormat
- fastHalt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
- fastHalt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
- fastHalt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- fastHalt(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- fastHalt(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- fastHalt(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- fastHalt_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- fastHalt_args(TabletClientService.fastHalt_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
-
Performs a deep copy on other.
- fastHalt_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- fastHalt_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.fastHalt_call
- fastSkip(DataInput, Key, MutableByteSequence, Key, Key, int) - Static method in class org.apache.accumulo.core.file.rfile.RelativeKey
- FateOperation - Enum in org.apache.accumulo.core.master.thrift
- FateService - Class in org.apache.accumulo.core.master.thrift
- FateService() - Constructor for class org.apache.accumulo.core.master.thrift.FateService
- FateService.AsyncClient - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncClient.beginFateOperation_call - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncClient.executeFateOperation_call - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncClient.Factory - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncClient.finishFateOperation_call - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncClient.waitForFateOperation_call - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncIface - Interface in org.apache.accumulo.core.master.thrift
- FateService.AsyncProcessor<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncProcessor.beginFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncProcessor.executeFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncProcessor.finishFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- FateService.AsyncProcessor.waitForFateOperation<I extends FateService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- FateService.beginFateOperation_args - Class in org.apache.accumulo.core.master.thrift
- FateService.beginFateOperation_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- FateService.beginFateOperation_result - Class in org.apache.accumulo.core.master.thrift
- FateService.beginFateOperation_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- FateService.Client - Class in org.apache.accumulo.core.master.thrift
- FateService.Client.Factory - Class in org.apache.accumulo.core.master.thrift
- FateService.executeFateOperation_args - Class in org.apache.accumulo.core.master.thrift
- FateService.executeFateOperation_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- FateService.executeFateOperation_result - Class in org.apache.accumulo.core.master.thrift
- FateService.executeFateOperation_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- FateService.finishFateOperation_args - Class in org.apache.accumulo.core.master.thrift
- FateService.finishFateOperation_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- FateService.finishFateOperation_result - Class in org.apache.accumulo.core.master.thrift
- FateService.finishFateOperation_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- FateService.Iface - Interface in org.apache.accumulo.core.master.thrift
- FateService.Processor<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
- FateService.Processor.beginFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
- FateService.Processor.executeFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
- FateService.Processor.finishFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
- FateService.Processor.waitForFateOperation<I extends FateService.Iface> - Class in org.apache.accumulo.core.master.thrift
- FateService.waitForFateOperation_args - Class in org.apache.accumulo.core.master.thrift
- FateService.waitForFateOperation_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- FateService.waitForFateOperation_result - Class in org.apache.accumulo.core.master.thrift
- FateService.waitForFateOperation_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- fetch(ScannerBase) - Method in class org.apache.accumulo.core.util.ColumnFQ
- fetchColumn(IteratorSetting.Column) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- fetchColumn(IteratorSetting.Column) - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Adds a column to the list of columns that will be fetch by this scanner.
- fetchColumn(Text, Text) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- fetchColumn(Text, Text) - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Adds a column to the list of columns that will be fetched by this scanner.
- fetchColumnFamily(Text) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- fetchColumnFamily(Text) - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Adds a column family to the list of columns that will be fetched by this scanner.
- fetchColumns(Class<?>, Configuration, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Restricts the columns that will be mapped over for the single input table on this job.
- fetchColumns(Class<?>, Configuration, Collection<Pair<Text, Text>>) - 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.
- fetchColumns(Collection<Pair<Text, Text>>) - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
-
Restricts the columns that will be mapped over for this job for the default input table.
- fetchColumns(JobConf, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Restricts the columns that will be mapped over for this job.
- fetchColumns(Job, Collection<Pair<Text, Text>>) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Restricts the columns that will be mapped over for this job for the default input table.
- fetchedColumns - Variable in class org.apache.accumulo.core.client.impl.ScannerOptions
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- fieldForId(int) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- fieldForId(int) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- fieldForId(int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TColumn
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TCondition
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TKey
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TMutation
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.TRange
- fieldForId(int) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- fieldForId(int) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.Compacting
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- fieldForId(int) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- fieldForId(int) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- fieldForId(int) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- fieldForId(int) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- fieldForId(int) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- fieldForId(int) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- fieldForId(int) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- fieldForId(int) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- fieldForId(int) - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- fieldForId(int) - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
- fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- fieldForId(int) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- fieldForId(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- fieldForId(int) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- FILE - org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.TokenSource
- FileAccessOperation() - Constructor for class org.apache.accumulo.core.file.FileOperations.FileAccessOperation
- FileIOOperation() - Constructor for class org.apache.accumulo.core.file.FileOperations.FileIOOperation
- filename - Variable in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- filename - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
- FILENAME - org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
- filenames - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- FILENAMES - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
- FileOperations - Class in org.apache.accumulo.core.file
- FileOperations() - Constructor for class org.apache.accumulo.core.file.FileOperations
- FileOperations.FileAccessOperation<SubclassType extends FileOperations.FileAccessOperation<SubclassType>> - Class in org.apache.accumulo.core.file
-
Options common to all FileOperations.
- FileOperations.FileAccessOperationBuilder<SubbuilderType> - Interface in org.apache.accumulo.core.file
-
Builder interface parallel to
FileOperations.FileAccessOperation
. - FileOperations.FileIOOperation<SubclassType extends FileOperations.FileIOOperation<SubclassType>> - Class in org.apache.accumulo.core.file
-
Options common to all
FileOperation
s which perform reading or writing. - FileOperations.FileIOOperationBuilder<SubbuilderType> - Interface in org.apache.accumulo.core.file
-
Builder interface parallel to
FileOperations.FileIOOperation
. - FileOperations.FileReaderOperation<SubclassType extends FileOperations.FileReaderOperation<SubclassType>> - Class in org.apache.accumulo.core.file
-
Options common to all
FileOperations
which perform reads. - FileOperations.FileReaderOperationBuilder<SubbuilderType> - Interface in org.apache.accumulo.core.file
-
Builder interface parallel to
FileOperations.FileReaderOperation
. - FileOperations.GetFileSizeOperation - Class in org.apache.accumulo.core.file
-
Operation object for performing
getFileSize()
operations. - FileOperations.GetFileSizeOperationBuilder - Interface in org.apache.accumulo.core.file
-
Builder interface for
FileOperations.GetFileSizeOperation
, allowing execution ofgetFileSize()
operations. - FileOperations.NeedsFile<ReturnType> - Interface in org.apache.accumulo.core.file
-
Type wrapper to ensure that
forFile(...)
is called before other methods. - FileOperations.NeedsFileOrOuputStream<ReturnType> - Interface in org.apache.accumulo.core.file
- FileOperations.NeedsFileSystem<ReturnType> - Interface in org.apache.accumulo.core.file
-
Type wrapper to ensure that
inFileSystem(...)
is called before other methods. - FileOperations.NeedsRange<ReturnType> - Interface in org.apache.accumulo.core.file
-
Type wrapper to ensure that
overRange(...)
is called before other methods. - FileOperations.NeedsTableConfiguration<ReturnType> - Interface in org.apache.accumulo.core.file
-
Type wrapper to ensure that
withTableConfiguration(...)
is called before other methods. - FileOperations.OpenIndexOperation - Class in org.apache.accumulo.core.file
-
Operation object for opening an index.
- FileOperations.OpenIndexOperationBuilder - Interface in org.apache.accumulo.core.file
-
Builder interface parallel to
FileOperations.OpenIndexOperation
. - FileOperations.OpenReaderOperation - Class in org.apache.accumulo.core.file
-
Operation object for opening a full reader.
- FileOperations.OpenReaderOperationBuilder - Interface in org.apache.accumulo.core.file
-
Builder parallel to
FileOperations.OpenReaderOperation
. - FileOperations.OpenScanReaderOperation - Class in org.apache.accumulo.core.file
-
Operation object for opening a scan reader.
- FileOperations.OpenScanReaderOperationBuilder - Interface in org.apache.accumulo.core.file
-
Builder interface parallel to
FileOperations.OpenScanReaderOperation
. - FileOperations.OpenWriterOperation - Class in org.apache.accumulo.core.file
-
Operation object for constructing a writer.
- FileOperations.OpenWriterOperationBuilder - Interface in org.apache.accumulo.core.file
-
Builder interface parallel to
FileOperations.OpenWriterOperation
. - FileOutputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
- FileOutputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- FileOutputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
- FileOutputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
-
Deprecated.
- FileOutputConfigurator.Opts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
Configuration keys for
AccumuloConfiguration
. - FileOutputConfigurator.Opts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- FileReaderOperation() - Constructor for class org.apache.accumulo.core.file.FileOperations.FileReaderOperation
- files - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- files - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- FILES - org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
- FILES - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
- FileSKVIterator - Interface in org.apache.accumulo.core.file
- FileSKVWriter - Interface in org.apache.accumulo.core.file
- fillParamsObjectFromConfiguration(CryptoModuleParameters, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
- fillParamsObjectFromStringMap(CryptoModuleParameters, Map<String, String>) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
- filter(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
- filter(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
-
Subclasses must provide an implementation which examines the given key and value and determines (1) whether to accept the KV pair and (2) how far to advance the source iterator past the key.
- filter(Text, List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
- filter(Text, List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
- Filter - Class in org.apache.accumulo.core.bloomfilter
-
Defines the general behavior of a filter.
- Filter - Class in org.apache.accumulo.core.iterators
-
A SortedKeyValueIterator that filters entries from its source iterator.
- Filter() - Constructor for class org.apache.accumulo.core.bloomfilter.Filter
- Filter() - Constructor for class org.apache.accumulo.core.iterators.Filter
- Filter(int, int, int) - Constructor for class org.apache.accumulo.core.bloomfilter.Filter
-
Constructor.
- FilteredConstants - Class in org.apache.accumulo.core
- FilteredConstants() - Constructor for class org.apache.accumulo.core.FilteredConstants
- filterInvalidLabelsOnly(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
- FilterResult(boolean, SeekingFilter.AdvanceResult) - Constructor for class org.apache.accumulo.core.iterators.user.SeekingFilter.FilterResult
- FilterTransport - Class in org.apache.accumulo.core.rpc
-
Transport that simply wraps another transport.
- FilterTransport(TTransport) - Constructor for class org.apache.accumulo.core.rpc.FilterTransport
- finalize() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
- finalize() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.replication.thrift.WalEdits._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.security.thrift.TAuthenticationKey._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.security.thrift.TDelegationToken._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.security.thrift.TDelegationTokenConfig._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByName(String) - Static method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
-
Find the _Fields constant that matches name, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.replication.thrift.WalEdits._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.security.thrift.TAuthenticationKey._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.security.thrift.TDelegationToken._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.security.thrift.TDelegationTokenConfig._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftId(int) - Static method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
-
Find the _Fields constant that matches fieldId, or null if its not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.replication.thrift.WalEdits._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.security.thrift.TAuthenticationKey._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.security.thrift.TDelegationToken._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.security.thrift.TDelegationTokenConfig._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByThriftIdOrThrow(int) - Static method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
-
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
- findByValue(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.ConfigurationType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TableOperation
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.data.thrift.TCMStatus
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.BulkImportState
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.FateOperation
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterGoalState
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.MasterState
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.master.thrift.TabletLoadState
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorErrorCode
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionReason
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanState
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ScanType
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TDurability
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findByValue(int) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TUnloadTabletGoal
-
Find a the enum type by its integer value, as defined in the Thrift IDL.
- findChildren(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- findChildren(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- findContainingExtent(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- findContainingExtent(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- findMax(Scanner, Text, boolean, Text, boolean) - Static method in class org.apache.accumulo.core.client.admin.FindMax
- FindMax - Class in org.apache.accumulo.core.client.admin
- FindMax() - Constructor for class org.apache.accumulo.core.client.admin.FindMax
- findOverlapping(KeyExtent, SortedMap<KeyExtent, ?>) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- findOverlapping(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- findOverlapping(KeyExtent, SortedMap<KeyExtent, ?>) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- findOverlapping(KeyExtent, SortedSet<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- findTop() - Method in class org.apache.accumulo.core.iterators.Filter
-
Iterates over the source until an acceptable key/value pair is found.
- findTop() - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
- finished - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- FINISHED - org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
- finishFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
- finishFateOperation() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.Processor.finishFateOperation
- finishFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client
- finishFateOperation(TInfo, TCredentials, long) - Method in interface org.apache.accumulo.core.master.thrift.FateService.Iface
- finishFateOperation(TInfo, TCredentials, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient
- finishFateOperation(TInfo, TCredentials, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.FateService.AsyncIface
- finishFateOperation_args() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- finishFateOperation_args(FateService.finishFateOperation_args) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
-
Performs a deep copy on other.
- finishFateOperation_args(TInfo, TCredentials, long) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- finishFateOperation_call(TInfo, TCredentials, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.finishFateOperation_call
- finishFateOperation_result() - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- finishFateOperation_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- finishFateOperation_result(FateService.finishFateOperation_result) - Constructor for class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
-
Performs a deep copy on other.
- fireError(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
- fireEvent(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
- FirstEntryInRowIterator - Class in org.apache.accumulo.core.iterators
- FirstEntryInRowIterator() - Constructor for class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
- FirstEntryInRowIterator(FirstEntryInRowIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
- FIXED_LEN_ENCODER - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
- FIXED_LONG_ARRAY_ENCODER - Static variable in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
- FixedByteArrayOutputStream - Class in org.apache.accumulo.core.client.lexicoder.impl
-
Uses a fixed length array and will not grow in size dynamically like the
ByteArrayOutputStream
. - FixedByteArrayOutputStream(byte[]) - Constructor for class org.apache.accumulo.core.client.lexicoder.impl.FixedByteArrayOutputStream
- FIXEDLEN - org.apache.accumulo.core.iterators.LongCombiner.Type
-
indicates a fixed-length (8-byte) encoding of a Long using
LongCombiner.FixedLenEncoder
- FIXEDLEN - org.apache.accumulo.core.iterators.user.SummingArrayCombiner.Type
-
indicates a fixed-length (8 bytes for each Long) encoding of a list of Longs using
SummingArrayCombiner.FixedLongArrayEncoder
- FixedLenEncoder() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner.FixedLenEncoder
- FixedLongArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.FixedLongArrayEncoder
- flatten() - Method in class org.apache.accumulo.core.security.ColumnVisibility
-
Generates a byte[] that represents a normalized, but logically equivalent, form of this evaluator's expression.
- FloatLexicoder - Class in org.apache.accumulo.core.client.lexicoder
-
A lexicoder for preserving the native Java sort order of Float values.
- FloatLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.FloatLexicoder
- flush() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
- flush() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
- flush() - Method in interface org.apache.accumulo.core.client.BatchWriter
-
Send any buffered mutations to Accumulo immediately.
- flush() - Method in class org.apache.accumulo.core.client.impl.BatchWriterImpl
- flush() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
- flush() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchWriter
- flush() - Method in class org.apache.accumulo.core.client.mock.MockBatchWriter
-
Deprecated.
- flush() - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
-
Deprecated.
- flush() - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
-
Send mutations for all tables to accumulo.
- flush() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
- flush() - Method in class org.apache.accumulo.core.rpc.FilterTransport
- flush() - Method in class org.apache.accumulo.core.security.crypto.BlockedOutputStream
- flush() - Method in class org.apache.accumulo.core.security.crypto.NoFlushOutputStream
- flush(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Deprecated.since 1.4; use
TableOperations.flush(String, Text, Text, boolean)
instead - flush(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Deprecated.
- flush(String, Text, Text, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Flush a table's data that is currently in memory.
- flush(String, Text, Text, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- FLUSH - org.apache.accumulo.core.client.Durability
-
Write mutations to the write-ahead log, and ensure the data is stored on remote servers, but perhaps not on persistent storage.
- FLUSH - org.apache.accumulo.core.client.impl.thrift.TableOperation
- FLUSH - org.apache.accumulo.core.tabletserver.thrift.TDurability
- flush_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- flush_args(TabletClientService.flush_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
Performs a deep copy on other.
- flush_args(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- flush_call(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flush_call
- FLUSH_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
-
Holds flush IDs to enable waiting on a flush to complete
- FLUSH_ID - org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
- flushID - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- flushs - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- FLUSHS - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- flushTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
- flushTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
- flushTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- flushTablet(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- flushTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- flushTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- flushTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- flushTablet_args(TabletClientService.flushTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
Performs a deep copy on other.
- flushTablet_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- flushTablet_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flushTablet_call
- followingKey(PartialKey) - Method in class org.apache.accumulo.core.data.Key
-
Returns a key that will sort immediately after this key.
- followingPrefix(Text) - Static method in class org.apache.accumulo.core.data.Range
-
Returns a Text that sorts just after all Texts beginning with a prefix.
- force - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- FORCE - org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
- forClient(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.rpc.SslConnectionParams
- forConfig(AccumuloConfiguration, boolean) - Static method in class org.apache.accumulo.core.rpc.SslConnectionParams
- forFile(String) - Method in class org.apache.accumulo.core.file.FileOperations.FileAccessOperation
-
Specify the file this operation should apply to.
- forFile(String) - Method in interface org.apache.accumulo.core.file.FileOperations.NeedsFile
-
Specify the file this operation should apply to.
- forFile(String, FileSystem, Configuration) - Method in class org.apache.accumulo.core.file.FileOperations.FileAccessOperation
-
Specify the file this operation should apply to.
- forFile(String, FileSystem, Configuration) - Method in interface org.apache.accumulo.core.file.FileOperations.NeedsFile
-
Specify the file this operation should apply to.
- format(long) - Static method in class org.apache.accumulo.core.util.Duration
- format(long, String, String) - Static method in class org.apache.accumulo.core.util.Duration
- format(Date, StringBuffer, FieldPosition) - Method in class org.apache.accumulo.core.util.format.FormatterConfig.DefaultDateFormat
- formatEntry(Map.Entry<Key, Value>) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
- formatEntry(Map.Entry<Key, Value>, boolean) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
-
if showTimestamps, will use
FormatterConfig.DefaultDateFormat
.
Preferably, useDefaultFormatter.formatEntry(java.util.Map.Entry, org.apache.accumulo.core.util.format.FormatterConfig)
- formatEntry(Map.Entry<Key, Value>, boolean, int) - Static method in class org.apache.accumulo.core.util.format.BinaryFormatter
-
Deprecated.
- formatEntry(Map.Entry<Key, Value>, DateFormat) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
-
Does not show timestamps if timestampFormat is null
- formatEntry(Map.Entry<Key, Value>, FormatterConfig) - Static method in class org.apache.accumulo.core.util.format.DefaultFormatter
- Formatter - Interface in org.apache.accumulo.core.util.format
- FormatterConfig - Class in org.apache.accumulo.core.util.format
-
Holds configuration settings for a
Formatter
- FormatterConfig() - Constructor for class org.apache.accumulo.core.util.format.FormatterConfig
- FormatterConfig(FormatterConfig) - Constructor for class org.apache.accumulo.core.util.format.FormatterConfig
-
Copies most fields, but still points to other.dateFormatSupplier.
- FormatterConfig.DefaultDateFormat - Class in org.apache.accumulo.core.util.format
-
Formats with milliseconds since epoch
- FormatterFactory - Class in org.apache.accumulo.core.util.format
- forOutputStream(String, FSDataOutputStream, Configuration) - Method in interface org.apache.accumulo.core.file.FileOperations.NeedsFileOrOuputStream
-
Specify the file this operation should apply to.
- forOutputStream(String, FSDataOutputStream, Configuration) - Method in class org.apache.accumulo.core.file.FileOperations.OpenWriterOperation
- forServer(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.rpc.SslConnectionParams
- forTableId(ClientContext, String) - Static method in class org.apache.accumulo.core.metadata.MetadataServicer
- forTableName(ClientContext, String) - Static method in class org.apache.accumulo.core.metadata.MetadataServicer
- FRACTION - org.apache.accumulo.core.conf.PropertyType
- from(String) - Static method in class org.apache.accumulo.core.replication.ReplicationTarget
-
Deserialize a ReplicationTarget
- from(String...) - Method in interface org.apache.accumulo.core.client.rfile.RFile.InputArguments
-
Specify RFiles to read from.
- from(RFileSource...) - Method in interface org.apache.accumulo.core.client.rfile.RFile.InputArguments
-
Specify RFiles to read from.
- from(Text) - Static method in class org.apache.accumulo.core.replication.ReplicationTarget
-
Deserialize a ReplicationTarget
- fromBytes(byte[]) - Static method in class org.apache.accumulo.core.tabletserver.log.LogEntry
- fromEntry(Map.Entry<K1, V1>) - Static method in class org.apache.accumulo.core.util.Pair
- fromFile(File) - Static method in class org.apache.accumulo.core.client.ClientConfiguration
-
Initializes a configuration object from the contents of a configuration file.
- fromKeyValue(Key, Value) - Static method in class org.apache.accumulo.core.tabletserver.log.LogEntry
- fromMap(Map<String, String>) - Static method in class org.apache.accumulo.core.client.ClientConfiguration
-
Initializes a configuration object from the contents of a map.
- fromParts(String, int) - Static method in class org.apache.accumulo.core.util.HostAndPort
-
Build a HostAndPort instance from separate host and port values.
- fromString(String) - Static method in class org.apache.accumulo.core.client.impl.DurabilityImpl
- fromString(String) - Static method in class org.apache.accumulo.core.util.HostAndPort
-
Split a freeform string into a host and port, without strict validation.
- fromStrings(String...) - Static method in class org.apache.accumulo.core.util.ByteArraySet
- fromStrings(Collection<String>) - Static method in class org.apache.accumulo.core.util.ByteArraySet
- fromThrift(TCredentials) - Static method in class org.apache.accumulo.core.client.impl.Credentials
-
Converts a given thrift object to our internal Credentials representation.
- fromThrift(TDurability) - Static method in class org.apache.accumulo.core.client.impl.DurabilityImpl
- fromThrift(TSamplerConfiguration) - Static method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
- fs - Variable in class org.apache.accumulo.core.volume.VolumeImpl
- FULL - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
-
compaction that merges all of a tablets files into one file
- FULL - org.apache.accumulo.core.tabletserver.thrift.CompactionType
- FULL_SCANS - org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
- fullScans - Variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
- FutureLocationColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.FutureLocationColumnFamily
G
- GC_CLIENT - org.apache.accumulo.core.util.ServerServices.Service
- GC_CYCLE_DELAY - org.apache.accumulo.core.conf.Property
- GC_CYCLE_START - org.apache.accumulo.core.conf.Property
- GC_DELETE_THREADS - org.apache.accumulo.core.conf.Property
- GC_FILE_ARCHIVE - org.apache.accumulo.core.conf.Property
- GC_METRICS_ENABLED - org.apache.accumulo.core.conf.Property
- GC_PORT - org.apache.accumulo.core.conf.Property
- GC_POST_ACTION - org.apache.accumulo.core.conf.PropertyType
- GC_PREFIX - org.apache.accumulo.core.conf.Property
- GC_TRACE_PERCENT - org.apache.accumulo.core.conf.Property
- GC_TRASH_IGNORE - org.apache.accumulo.core.conf.Property
- GC_USE_FULL_COMPACTION - org.apache.accumulo.core.conf.Property
- GcCycleStats - Class in org.apache.accumulo.core.gc.thrift
- GcCycleStats() - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
- GcCycleStats(long, long, long, long, long, long) - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
- GcCycleStats(GcCycleStats) - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
Performs a deep copy on other.
- GcCycleStats._Fields - Enum in org.apache.accumulo.core.gc.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- GCMonitorService - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService
- GCMonitorService.AsyncClient - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.AsyncClient.Factory - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.AsyncClient.getStatus_call - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.AsyncIface - Interface in org.apache.accumulo.core.gc.thrift
- GCMonitorService.AsyncProcessor<I extends GCMonitorService.AsyncIface> - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.AsyncProcessor.getStatus<I extends GCMonitorService.AsyncIface> - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.Client - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.Client.Factory - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.getStatus_args - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.getStatus_args._Fields - Enum in org.apache.accumulo.core.gc.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- GCMonitorService.getStatus_result - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.getStatus_result._Fields - Enum in org.apache.accumulo.core.gc.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- GCMonitorService.Iface - Interface in org.apache.accumulo.core.gc.thrift
- GCMonitorService.Processor<I extends GCMonitorService.Iface> - Class in org.apache.accumulo.core.gc.thrift
- GCMonitorService.Processor.getStatus<I extends GCMonitorService.Iface> - Class in org.apache.accumulo.core.gc.thrift
- GCStatus - Class in org.apache.accumulo.core.gc.thrift
- GCStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
- GCStatus(GcCycleStats, GcCycleStats, GcCycleStats, GcCycleStats) - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
- GCStatus(GCStatus) - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
-
Performs a deep copy on other.
- GCStatus._Fields - Enum in org.apache.accumulo.core.gc.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- GENERAL_CLASSPATHS - org.apache.accumulo.core.conf.Property
- GENERAL_DELEGATION_TOKEN_LIFETIME - org.apache.accumulo.core.conf.Property
- GENERAL_DELEGATION_TOKEN_UPDATE_INTERVAL - org.apache.accumulo.core.conf.Property
- GENERAL_DYNAMIC_CLASSPATHS - org.apache.accumulo.core.conf.Property
- GENERAL_KERBEROS_KEYTAB - org.apache.accumulo.core.conf.Property
- GENERAL_KERBEROS_PRINCIPAL - org.apache.accumulo.core.conf.Property
- GENERAL_KERBEROS_RENEWAL_PERIOD - org.apache.accumulo.core.conf.Property
- GENERAL_LEGACY_METRICS - org.apache.accumulo.core.conf.Property
- GENERAL_MAVEN_PROJECT_BASEDIR - org.apache.accumulo.core.conf.Property
- GENERAL_MAX_MESSAGE_SIZE - org.apache.accumulo.core.conf.Property
- GENERAL_MAX_SCANNER_RETRY_PERIOD - org.apache.accumulo.core.conf.Property
- GENERAL_PREFIX - org.apache.accumulo.core.conf.Property
- GENERAL_RPC_SERVER_TYPE - org.apache.accumulo.core.conf.Property
- GENERAL_RPC_TIMEOUT - org.apache.accumulo.core.conf.Property
- GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- GENERAL_SECURITY_CREDENTIAL_PROVIDER_PATHS - org.apache.accumulo.core.conf.Property
- GENERAL_SIMPLETIMER_THREADPOOL_SIZE - org.apache.accumulo.core.conf.Property
- GENERAL_VOLUME_CHOOSER - org.apache.accumulo.core.conf.Property
- GENERATED_TABLET_DIRECTORY_PREFIX - Static variable in class org.apache.accumulo.core.Constants
- generateInitialTableProperties(boolean) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
-
Generate the initial (default) properties for a table
- generateNewRandomSessionKey(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.CryptoModule
-
Generates a random session key and sets it into the
CryptoModuleParameters.getPlaintextKey()
property. - generateNewRandomSessionKey(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
- get() - Method in class org.apache.accumulo.core.data.Value
-
Gets the byte data of this value.
- get() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
-
Get a sorted List of all elements in this queue, in descending order.
- get() - Method in class org.apache.accumulo.core.util.format.DateFormatSupplier
-
Always sets the TimeZone, which is a fast operation
- get(int) - Method in class org.apache.accumulo.core.util.PreAllocatedArray
-
Get the item stored at the specified index.
- get(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
- get(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property value from this configuration.
- get(String) - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
- get(String) - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
- get(K) - Method in class org.apache.accumulo.core.util.StopWatch
- get(KT) - Method in class org.apache.accumulo.core.util.MapCounter
- get(ClientConfiguration.ClientProperty) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Returns the value for prop, the default value if not present.
- get(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property value from this configuration.
- get(Property) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
- get(Property) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
- get(Property) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
- getAccumuloConfiguration(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
-
This helper method provides an AccumuloConfiguration object constructed from the Accumulo defaults, and overridden with Accumulo properties that have been stored in the Job's configuration.
- getAccumuloConfiguration(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- getAccumuloConfiguration(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
-
Deprecated.since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to discourage its use.
- getAccumuloConfiguration(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
-
Deprecated.since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to discourage its use.
- getAccumuloProperty() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
-
Deprecated.since 1.7.0 This method returns a type that is not part of the public API and not guaranteed to be stable.
- getActiveCompactions() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
- getActiveCompactions() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
- getActiveCompactions(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
-
List the active compaction running on a tablet server
- getActiveCompactions(String) - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
- getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- getActiveCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- getActiveCompactions_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- getActiveCompactions_args(TabletClientService.getActiveCompactions_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
-
Performs a deep copy on other.
- getActiveCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- getActiveCompactions_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveCompactions_call
- getActiveCompactions_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- getActiveCompactions_result(List<ActiveCompaction>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- getActiveCompactions_result(TabletClientService.getActiveCompactions_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
-
Performs a deep copy on other.
- getActiveLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveLogs
- getActiveLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveLogs
- getActiveLogs(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- getActiveLogs(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- getActiveLogs(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- getActiveLogs(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- getActiveLogs_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- getActiveLogs_args(TabletClientService.getActiveLogs_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
-
Performs a deep copy on other.
- getActiveLogs_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- getActiveLogs_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveLogs_call
- getActiveLogs_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- getActiveLogs_result(List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- getActiveLogs_result(TabletClientService.getActiveLogs_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
-
Performs a deep copy on other.
- getActiveScans() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
- getActiveScans() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveScans
- getActiveScans(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
-
List the active scans on tablet server.
- getActiveScans(String) - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
- getActiveScans(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- getActiveScans(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- getActiveScans(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- getActiveScans(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- getActiveScans_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- getActiveScans_args(TabletClientService.getActiveScans_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
-
Performs a deep copy on other.
- getActiveScans_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- getActiveScans_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveScans_call
- getActiveScans_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- getActiveScans_result(List<ActiveScan>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- getActiveScans_result(TabletClientService.getActiveScans_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
-
Performs a deep copy on other.
- getActiveTservers() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getActiveTservers
- getActiveTservers() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getActiveTservers
- getActiveTservers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
- getActiveTservers(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
- getActiveTservers(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
- getActiveTservers(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
- getActiveTservers_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- getActiveTservers_args(MasterClientService.getActiveTservers_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
-
Performs a deep copy on other.
- getActiveTservers_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- getActiveTservers_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getActiveTservers_call
- getActiveTservers_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- getActiveTservers_result(List<String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- getActiveTservers_result(MasterClientService.getActiveTservers_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
-
Performs a deep copy on other.
- getAddress(ServerServices.Service) - Method in class org.apache.accumulo.core.util.ServerServices
- getAddressString(ServerServices.Service) - Method in class org.apache.accumulo.core.util.ServerServices
- getAge() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getAge() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getAge() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getAge() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getAggregator(Key) - Method in class org.apache.accumulo.core.iterators.aggregation.conf.AggregatorSet
-
Deprecated.
- getAlgorithmName() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the name of the symmetric algorithm to use for encryption.
- getAliasesFromHadoopCredentialProvider(Configuration) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- getAllOptions() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the overall set of options for the
CryptoModule
. - getAllPropertiesWithPrefix(ClientConfiguration.ClientProperty) - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Gets all properties under the given prefix in this configuration.
- getAllPropertiesWithPrefix(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets all properties under the given prefix in this configuration.
- getAnyTransport(List<ThriftTransportKey>, boolean) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
- getAPIVersion() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
-
Get version of BCFile API.
- getApplication() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
- getArguments() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getArgumentsIterator() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getArgumentsSize() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient.Factory
- getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.Factory
- getAuthenticationToken(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
- getAuthenticationToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
- getAuthenticationToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
- getAuthenticationToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
- getAuthenticationToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Gets the authenticated token from either the specified token file or directly from the configuration, whichever was used when the job was configured.
- getAuthorizationFailures() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
-
Deprecated.since 1.5, see
MutationsRejectedException.getAuthorizationFailuresMap()
- getAuthorizationFailures() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- getAuthorizationFailuresMap() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
-
Deprecated.since 1.7.0 see
MutationsRejectedException.getSecurityErrorCodes()
- getAuthorizationFailuresSize() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- getAuthorizations() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getAuthorizations() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
- getAuthorizations() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
- getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.BaseIteratorEnvironment
- getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
- getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
- getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
- getAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- getAuthorizations() - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
-
Deprecated.
- getAuthorizations() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Returns the authorizations that have been set on the scanner
- getAuthorizations() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
-
Deprecated.Use
Constraint.Environment.getAuthorizationsContainer()
instead. - getAuthorizations() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
- getAuthorizations() - Method in class org.apache.accumulo.core.security.Authorizations
-
Gets the authorizations in sorted order.
- getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getAuthorizationsArray() - Method in class org.apache.accumulo.core.security.Authorizations
-
Returns a serialized form of these authorizations.
- getAuthorizationsBB() - Method in class org.apache.accumulo.core.security.Authorizations
-
Gets the authorizations in sorted order.
- getAuthorizationsContainer() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
-
Gets the authorizations in the environment.
- getAuthorizationsIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getAuthorizationsSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getAuths() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getAutoAdjustRanges(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Determines whether a configuration has auto-adjust ranges enabled.
- getAutoAdjustRanges(Class<?>, Configuration) - 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.
- getAutoAdjustRanges(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Determines whether a configuration has auto-adjust ranges enabled.
- getAutoAdjustRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Determines whether a configuration has auto-adjust ranges enabled.
- getAverage() - Method in class org.apache.accumulo.core.util.Stat
- getBackingArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
- getBackingArray() - Method in class org.apache.accumulo.core.data.ByteSequence
-
Gets the backing byte array for this sequence.
- getBadTServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getBadTServersSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getBasePath() - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
- getBasePath() - Method in interface org.apache.accumulo.core.volume.Volume
-
The base path which Accumulo will use within the given
FileSystem
- getBasePath() - Method in class org.apache.accumulo.core.volume.VolumeImpl
- getBatch() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getBatchFromServer(ClientContext, Range, KeyExtent, String, SortedMap<Key, Value>, SortedSet<Column>, List<IterInfo>, Map<String, Map<String, String>>, int, Authorizations, boolean, long, String) - Static method in class org.apache.accumulo.core.client.impl.ThriftScanner
- getBatchScanner(Connector, int) - Static method in class org.apache.accumulo.core.replication.ReplicationTable
- getBatchSize() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
- getBatchSize() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
- getBatchSize() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
- getBatchSize() - Method in class org.apache.accumulo.core.client.IsolatedScanner
- getBatchSize() - Method in class org.apache.accumulo.core.client.mock.MockScanner
-
Deprecated.
- getBatchSize() - Method in interface org.apache.accumulo.core.client.Scanner
-
Returns the batch size (number of Key/Value pairs) that will be fetched at a time from a tablet server.
- getBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getBatchTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- getBatchTimeout(TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Returns the timeout to fill a batch in the given TimeUnit.
- getBatchTimeOut() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getBatchTimeOut() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getBatchWriter(String) - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
- getBatchWriter(String) - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
-
Deprecated.
- getBatchWriter(String) - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
-
Returns a BatchWriter for a particular table.
- getBatchWriter(Connector) - Static method in class org.apache.accumulo.core.replication.ReplicationTable
- getBatchWriterConfig() - Method in class org.apache.accumulo.core.cli.BatchWriterOpts
- getBatchWriterOptions(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
-
Gets the
BatchWriterConfig
settings. - getBatchWriterOptions(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.
- getBatchWriterOptions(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Gets the
BatchWriterConfig
settings. - getBatchWriterOptions(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Gets the
BatchWriterConfig
settings. - getBCFileVersion() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
-
Get version of BCFile file being read.
- getBigDecimal(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
- getBigDecimal(String, BigDecimal) - 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
- getBigInteger(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
- getBigInteger(String, BigInteger) - 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
- getBlock(String) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
-
Fetch block from cache.
- getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Get the buffer of the block with the specified name.
- getBlockCount() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
-
Get the number of data blocks.
- getBlockNoStats(String) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
- getBlockNoStats(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
- getBlockStreamSize() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the size of the buffering stream that sits above the cipher stream
- getBoolean(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
- getBoolean(String, 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
- getBoolean(String, 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
- getBoolean(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property of type
PropertyType.BOOLEAN
, interpreting the value properly (usingBoolean.parseBoolean()
). - getBuffer() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
- getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- getBuffer() - Method in interface org.apache.accumulo.core.file.blockfile.cache.CacheEntry
- getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
-
The byte array returned by this method is only for read optimizations, it should not be modified.
- getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
- getBuffer() - Method in class org.apache.accumulo.core.rpc.FilterTransport
- getBufferPosition() - Method in class org.apache.accumulo.core.rpc.FilterTransport
- getBulkImports() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getBulkImports() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getBulkImportsIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getBulkImportsIterator() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getBulkImportsSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getBulkImportsSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getByDepth(int) - Static method in enum org.apache.accumulo.core.data.PartialKey
-
Deprecated.since 1.7.0
- getByte(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
- getByte(String, byte) - 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
- getByte(String, Byte) - 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
- getByteBuffer(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
- getBytes() - Method in class org.apache.accumulo.core.data.ComparableBytes
-
Deprecated.Gets the wrapped bytes in this object.
- getBytes() - Method in class org.apache.accumulo.core.data.impl.ComparableBytes
-
Gets the wrapped bytes in this object.
- getBytes(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
- getBytesRemainingInBuffer() - Method in class org.apache.accumulo.core.rpc.FilterTransport
- getCachedMetaBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
- getCacheFiles(Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
- getCallbackHandler() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
-
The SASL callback handler for this mechanism, may be null.
- getCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- getCf() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- getCfg() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- getChildren() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
- getCipher() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the initialized cipher object.
- getCipher(String) - Static method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModuleUtils
- getClassLoaderContext() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
-
Returns the name of the current classloader context set on this scanner
- getClassLoaderContext() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- getClassLoaderContext() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Returns the name of the current classloader context set on this scanner
- getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getClassLoaderContext(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Gets the name of the context classloader to use for scans
- getClassLoaderContext(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Returns the name of the current classloader context set on this scanner
- getClassLoaderContext(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Returns the name of the current classloader context set on this scanner
- getClassName() - Method in class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
- getClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- getClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- getClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- getClassName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- getClassName() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
-
Deprecated.
- getClassName() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
- getClassName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- getClient() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getClient() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getClient() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getClient(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client.Factory
- getClient(TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client.Factory
- getClient(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
- getClient(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client.Factory
- getClient(TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client.Factory
- getClient(TProtocol) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client.Factory
- getClient(TProtocol) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Client.Factory
- getClient(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.master.thrift.FateService.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Client.Factory
- getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client.Factory
- getClient(TServiceClientFactory<T>, HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
-
Create a Thrift client using the given factory with a pooled transport (if available), the address and client context.
- getClient(TServiceClientFactory<T>, HostAndPort, ClientContext, long) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
-
Create a Thrift client using the given factory with a pooled transport (if available) using the address, client context and timeou
- getClientConfiguration() - Method in class org.apache.accumulo.core.cli.ClientOpts
- getClientConfiguration(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Obtain a
ClientConfiguration
based on the configuration. - getClientConfiguration(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Fetch the client configuration from the job.
- getClientConfiguration(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Construct the
ClientConfiguration
given the provided context. - getClientNoTimeout(TServiceClientFactory<T>, HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
-
Create a Thrift client using the given factory with a pooled transport (if available), the address, and client context with no timeout.
- getClientProtocol() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getClientSslParams() - Method in class org.apache.accumulo.core.client.impl.ClientContext
-
Retrieve SSL/TLS configuration to initiate an RPC connection to a server
- getClientString() - Method in class org.apache.accumulo.core.rpc.TBufferedSocket
- getClientTimeoutInMillis() - Method in class org.apache.accumulo.core.client.impl.ClientContext
-
Retrieve the universal RPC client timeout from the configuration
- getCloseUnderylingStreamAfterCryptoStreamClose() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the flag that indicates whether or not to close the underlying stream when the cipher stream is closed.
- getCmid() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- getCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- getCode() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- getCode() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- getColFamily() - Method in class org.apache.accumulo.core.data.thrift.TKey
- getColQualifier() - Method in class org.apache.accumulo.core.data.thrift.TKey
- getColumnFamilies() - Method in class org.apache.accumulo.core.file.FileOperations.OpenScanReaderOperation
-
The column families which this reader should scan.
- getColumnFamily() - Method in class org.apache.accumulo.core.client.IteratorSetting.Column
- getColumnFamily() - Method in class org.apache.accumulo.core.data.Column
-
Gets the column family.
- getColumnFamily() - Method in class org.apache.accumulo.core.data.ColumnUpdate
-
Gets the column family for this update.
- getColumnFamily() - Method in class org.apache.accumulo.core.data.Key
-
Gets the column family as a
Text
object. - getColumnFamily() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- getColumnFamily() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
-
Deprecated.
- getColumnFamily() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
- getColumnFamily() - Method in class org.apache.accumulo.core.util.ColumnFQ
- getColumnFamily(Text) - Method in class org.apache.accumulo.core.data.Key
-
Writes the column family into the given
Text
. - getColumnFamilyData() - Method in class org.apache.accumulo.core.data.Key
-
Returns the column family as a byte sequence.
- getColumnQualifier() - Method in class org.apache.accumulo.core.client.IteratorSetting.Column
- getColumnQualifier() - Method in class org.apache.accumulo.core.data.Column
-
Gets the column qualifier.
- getColumnQualifier() - Method in class org.apache.accumulo.core.data.ColumnUpdate
-
Gets the column qualifier for this update.
- getColumnQualifier() - Method in class org.apache.accumulo.core.data.Key
-
Gets the column qualifier as a
Text
object. - getColumnQualifier() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- getColumnQualifier() - Method in class org.apache.accumulo.core.iterators.conf.PerColumnIteratorConfig
-
Deprecated.
- getColumnQualifier() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
- getColumnQualifier() - Method in class org.apache.accumulo.core.util.ColumnFQ
- getColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
-
Writes the column qualifier into the given
Text
. - getColumnQualifierData() - Method in class org.apache.accumulo.core.data.Key
-
Returns the column qualifier as a byte sequence.
- getColumns() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getColumns() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getColumnsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getColumnsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getColumnVisibility() - Method in class org.apache.accumulo.core.data.Column
-
Gets the column visibility.
- getColumnVisibility() - Method in class org.apache.accumulo.core.data.ColumnUpdate
-
Gets the column visibility for this update.
- getColumnVisibility() - Method in class org.apache.accumulo.core.data.Key
-
Gets the column visibility as a
Text
object. - getColumnVisibility() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- getColumnVisibility(Text) - Method in class org.apache.accumulo.core.data.Key
-
Writes the column visibvility into the given
Text
. - getColumnVisibilityData() - Method in class org.apache.accumulo.core.data.Key
-
Returns the column visibility as a byte sequence.
- getColumnVisibilityParsed() - Method in class org.apache.accumulo.core.data.Key
-
Gets the column visibility.
- getColVisibility() - Method in class org.apache.accumulo.core.data.thrift.TKey
- getCompactionStrategy() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
- getCompactionStrategyOptions(AccumuloConfiguration) - Static method in enum org.apache.accumulo.core.conf.Property
-
Collects together properties from the given configuration pertaining to compaction strategies.
- getCompressedSize() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
- getCompressedSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
- getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
-
Get the compressed size of the block.
- getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
-
Get the compressed size of the block in progress.
- getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- getCompression() - Method in class org.apache.accumulo.core.file.FileOperations.OpenWriterOperation
- getCompressionName() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
-
Get the name of the compression algorithm used to compress the block.
- getCompressor() - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- getConditions() - Method in class org.apache.accumulo.core.data.ConditionalMutation
- getConditions() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- getConditionsIterator() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- getConditionsSize() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- getConf() - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
- getConf() - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
- getConfig() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
-
A configuration from the requesting user, may be null.
- getConfig() - Method in class org.apache.accumulo.core.client.impl.BaseIteratorEnvironment
- getConfig() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
- getConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
- getConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
- getConfiguration() - Method in class org.apache.accumulo.core.client.impl.ClientContext
-
Retrieve the configuration used to construct this context
- getConfiguration() - Method in interface org.apache.accumulo.core.client.Instance
-
Deprecated.since 1.6.0. This method makes very little sense in the context of the client API and never should have been exposed.
- getConfiguration() - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getConfiguration() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
-
Deprecated.
- getConfiguration() - Method in class org.apache.accumulo.core.file.FileOperations.FileAccessOperation
- getConfiguration(int) - 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
- getConfiguration(String) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Create a Hadoop
Configuration
with the appropriate members to access CredentialProviders - getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- getConfiguration(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- getConfiguration(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- getConfiguration(Configuration, String) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Adds the Credential Provider configuration elements to the provided
Configuration
. - getConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- getConfiguration_args(ClientService.getConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
Performs a deep copy on other.
- getConfiguration_args(TInfo, TCredentials, ConfigurationType) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- getConfiguration_call(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getConfiguration_call
- getConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- getConfiguration_result(Map<String, String>) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- getConfiguration_result(ClientService.getConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
-
Performs a deep copy on other.
- getConfigurationListeners() - 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
- getConfiguredBaseDir(AccumuloConfiguration, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
-
Deprecated.
- getConnection(ClientContext) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
- getConnection(ClientContext) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- getConnection(ClientContext, boolean) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- getConnection(ClientContext, boolean, long) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- getConnection(ClientContext, TServiceClientFactory<CT>) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- getConnection(ClientContext, TServiceClientFactory<CT>, boolean, long) - Static method in class org.apache.accumulo.core.client.impl.ServerClient
- getConnectionWithRetry(ClientContext) - Static method in class org.apache.accumulo.core.client.impl.MasterClient
- getConnector() - Method in class org.apache.accumulo.core.cli.ClientOpts
- getConnector() - Method in class org.apache.accumulo.core.client.impl.ClientContext
-
Retrieve a connector
- getConnector(String, byte[]) - Method in interface org.apache.accumulo.core.client.Instance
-
Deprecated.since 1.5, use
Instance.getConnector(String, AuthenticationToken)
withPasswordToken
- getConnector(String, byte[]) - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getConnector(String, byte[]) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
-
Deprecated.
- getConnector(String, CharSequence) - Method in interface org.apache.accumulo.core.client.Instance
-
Deprecated.since 1.5, use
Instance.getConnector(String, AuthenticationToken)
withPasswordToken
- getConnector(String, CharSequence) - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getConnector(String, CharSequence) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
-
Deprecated.
- getConnector(String, ByteBuffer) - Method in interface org.apache.accumulo.core.client.Instance
-
Deprecated.since 1.5, use
Instance.getConnector(String, AuthenticationToken)
withPasswordToken
- getConnector(String, ByteBuffer) - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getConnector(String, ByteBuffer) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
-
Deprecated.
- getConnector(String, AuthenticationToken) - Method in interface org.apache.accumulo.core.client.Instance
-
Returns a connection to this instance of accumulo.
- getConnector(String, AuthenticationToken) - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getConnector(String, AuthenticationToken) - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
- getConstrainClass() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
- getConstrainClass() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- getConstraintViolationSummaries() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
- getCoordinatorConnection(ClientContext) - Static method in class org.apache.accumulo.core.client.impl.ReplicationClient
- getCoordinatorConnectionWithRetry(ClientContext) - Static method in class org.apache.accumulo.core.client.impl.ReplicationClient
- getCount() - Method in class org.apache.accumulo.core.iterators.system.CountingIterator
- getCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getCount(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property of type
PropertyType.COUNT
, interpreting the value properly (as an integer). - getCq() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- getCreationDate() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- getCredentialProviders(Configuration) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Wrapper to fetch the configured
List<CredentialProvider>
s. - getCredentials() - Method in class org.apache.accumulo.core.client.impl.ClientContext
-
Retrieve the credentials used to construct this context
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- getCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- getCredentials() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- getCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- getCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- getCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- getCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- getCryptoModule(String) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
- getCryptoModule(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
-
This method returns a crypto module based on settings in the given configuration parameter.
- getCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- getCurrentKey() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
- getCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- getCurrentSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Get the current size of this cache.
- getCurrentValue() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
- getCv() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- getCve() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- getData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getData() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- getData() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- getDataBlock(int) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
- getDataBlock(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
-
It is intended that once the BlockRead object is returned to the caller, that the caller will read the entire block and then call close on the BlockRead class.
- getDataBlock(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
-
Stream access to a Data Block.
- getDataBlock(long, long, long) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
- getDataBlock(long, long, long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
- getDataBlock(long, long, long) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
- getDataCache() - Method in class org.apache.accumulo.core.file.FileOperations.FileReaderOperation
- getDataCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getDataCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getDateFormatSupplier() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
- getDeadTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getDeadTabletServersIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getDeadTabletServersSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getDecompressor() - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- getDecryptingInputStream(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.CryptoModule
- getDecryptingInputStream(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
- getDeepCopyDataSource(IteratorEnvironment) - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
- getDefaultCompressionName() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
-
Get the name of the default compression algorithm.
- getDefaultConfiguration() - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets the default configuration.
- getDefaultFormatter(Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
- getDefaultInputTableConfig(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Returns the
InputTableConfig
for the configuration based on the properties set using the single-table input methods. - getDefaultRealm() - Static method in class org.apache.accumulo.core.rpc.SaslConnectionParams
- getDefaultTableName(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
-
Gets the default table name from the configuration.
- getDefaultTableName(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.
- getDefaultTableName(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Gets the default table name from the configuration.
- getDefaultTableName(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Gets the default table name from the configuration.
- getDefaultValue() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- getDefaultValue() - Method in enum org.apache.accumulo.core.conf.Property
-
Gets the default value for this property.
- getDefaultVolume(Configuration, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
- getDelegationToken() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getDelegationToken
- getDelegationToken() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getDelegationToken
- getDelegationToken(DelegationTokenConfig) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Obtain a
DelegationToken
for use when Kerberos credentials cannot be used (e.g. - getDelegationToken(DelegationTokenConfig) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
- getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
- getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
- getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
- getDelegationToken_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- getDelegationToken_args(MasterClientService.getDelegationToken_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
-
Performs a deep copy on other.
- getDelegationToken_args(TInfo, TCredentials, TDelegationTokenConfig) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- getDelegationToken_call(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getDelegationToken_call
- getDelegationToken_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- getDelegationToken_result(MasterClientService.getDelegationToken_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
-
Performs a deep copy on other.
- getDelegationToken_result(TDelegationToken, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- getDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- getDepth() - Method in enum org.apache.accumulo.core.data.PartialKey
-
Gets the depth of this partial key.
- getDescription() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- getDescription() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- getDescription() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
- getDescription() - Method in enum org.apache.accumulo.core.conf.Property
-
Gets the description of this property.
- getDescription() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
- getDesiredRate() - Method in interface org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory.RateProvider
-
Calculate the current rate for the
RateLimiter
. - getDiskUsage() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
- getDiskUsage() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
- getDiskUsage(Set<String>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Gets the number of bytes being used in the files for a set of tables
- getDiskUsage(Set<String>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- getDiskUsage(Set<String>, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- getDiskUsage(Set<String>, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- getDiskUsage(Set<String>, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- getDiskUsage(Set<String>, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- getDiskUsage_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- getDiskUsage_args(Set<String>, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- getDiskUsage_args(ClientService.getDiskUsage_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
Performs a deep copy on other.
- getDiskUsage_call(Set<String>, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getDiskUsage_call
- getDiskUsage_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- getDiskUsage_result(List<TDiskUsage>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- getDiskUsage_result(ClientService.getDiskUsage_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
Performs a deep copy on other.
- getDocID(Key) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- getDocID(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- getDouble(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
- getDouble(String, double) - 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
- getDouble(String, Double) - 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
- getDuplicateReads() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- getDurability() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
- getDurability() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
- getDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- getDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- getE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- getE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- getE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- getEdits() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- getEditsIterator() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- getEditsSize() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- getElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeLocalUserPassword
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ping
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeNamespacePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeSystemPermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeTablePermission
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.success
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.throwsError
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.fails
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.success
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.throwsError
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.beginFateOperation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.waitForFateOperation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.beginFateOperation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.executeFateOperation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.finishFateOperation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.waitForFateOperation
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.drainReplicationTable
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getActiveTservers
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getDelegationToken
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeNamespaceProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeSystemProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeTableProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportSplitExtent
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportTabletStatus
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setMasterGoalState
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setNamespaceProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setSystemProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setTableProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdown
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdownTabletServer
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForBalance
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForFlush
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.drainReplicationTable
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getActiveTservers
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getDelegationToken
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getMasterStats
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.initiateFlush
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeNamespaceProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeSystemProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeTableProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportSplitExtent
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportTabletStatus
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setMasterGoalState
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setNamespaceProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setSystemProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setTableProperty
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdown
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdownTabletServer
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForBalance
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForFlush
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor.getServicerAddress
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Processor.getServicerAddress
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateKeyValues
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateLog
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateKeyValues
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateLog
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveLogs
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startMultiScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeMultiScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueMultiScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveLogs
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveScans
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startMultiScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startScan
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
- getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
- getEncryptedInputStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the encrypted input stream to wrap for decryption.
- getEncryptedKey() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the encrypted version of the plaintext key.
- getEncryptedOutputStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the encrypted output stream, which is nearly always a wrapped version of the output stream from
CryptoModuleParameters.getPlaintextOutputStream()
. - getEncryptingOutputStream(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.CryptoModule
-
Takes a
CryptoModuleParameters
object containing anOutputStream
to wrap within aCipherOutputStream
. - getEncryptingOutputStream(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
- getEncryptionMode() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the name of the encryption mode to use for encryption.
- getEndKey() - Method in class org.apache.accumulo.core.data.Range
-
Gets the ending key, or null if the end is positive infinity.
- getEndRow() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
- getEndRow() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
-
Returns this extent's end row
- getEndRow() - Method in class org.apache.accumulo.core.data.impl.TabletIdImpl
- getEndRow() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getEndRow() - Method in interface org.apache.accumulo.core.data.TabletId
- getEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- getEndRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- getEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- getEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- getEntries() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getEntriesLeft() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
- getEntriesRead() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getEntriesRead() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getEntriesWritten() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getEntriesWritten() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getEquivalent(SystemPermission) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
- getEquivalent(TablePermission) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
- getErrorDir() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getErrorListeners() - 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
- getErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- getErrorServers() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
- getEstimatedSize() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- getEvictedCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- getEvictedCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Get the number of blocks that have been evicted during the lifetime of this cache.
- getEvictionCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- getEvictionCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Get the number of eviction runs that have occurred
- getEx() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- getExpirationDate() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- getExpirationDate() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- getExpirationDate() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- getExportedProps(FileSystem, Path) - Static method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- getExpression() - Method in class org.apache.accumulo.core.security.ColumnVisibility
-
Accessor for the underlying byte string.
- getExtent() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
-
Deprecated.since 1.7.0 use
ActiveCompaction.getTablet()
- getExtent() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
-
Deprecated.since 1.7.0 use
ActiveScan.getTablet()
- getExtent() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
-
Deprecated.
- getExtent() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
-
Deprecated.
- getExtent() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
-
Gets the key extent of the environment.
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- getFail() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getFailedExtents() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- getFailedExtentsSize() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- getFailures() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getFailuresSize() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getFamily() - Method in class org.apache.accumulo.core.data.Condition
-
Gets the column family of this condition.
- getFetchedColumns() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- getFetchedColumns() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
-
Returns the columns to be fetched for this configuration
- getFetchedColumns() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getFetchedColumns(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Gets the columns to be mapped over from this job.
- getFetchedColumns(Class<?>, Configuration) - 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.
- getFetchedColumns(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Gets the columns to be mapped over from this job.
- getFetchedColumns(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Gets the columns to be mapped over from this job.
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.replication.thrift.WalEdits._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.security.thrift.TAuthenticationKey._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.security.thrift.TDelegationToken._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.security.thrift.TDelegationTokenConfig._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
- getFieldName() - Method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
- getFieldValue(ClientService.authenticate_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- getFieldValue(ClientService.authenticate_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- getFieldValue(ClientService.authenticateUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- getFieldValue(ClientService.authenticateUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- getFieldValue(ClientService.bulkImportFiles_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getFieldValue(ClientService.bulkImportFiles_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- getFieldValue(ClientService.changeAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- getFieldValue(ClientService.changeAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- getFieldValue(ClientService.changeLocalUserPassword_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- getFieldValue(ClientService.changeLocalUserPassword_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- getFieldValue(ClientService.checkClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- getFieldValue(ClientService.checkClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- getFieldValue(ClientService.checkNamespaceClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- getFieldValue(ClientService.checkNamespaceClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- getFieldValue(ClientService.checkTableClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- getFieldValue(ClientService.checkTableClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- getFieldValue(ClientService.createLocalUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- getFieldValue(ClientService.createLocalUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- getFieldValue(ClientService.dropLocalUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- getFieldValue(ClientService.dropLocalUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- getFieldValue(ClientService.getConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- getFieldValue(ClientService.getConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- getFieldValue(ClientService.getDiskUsage_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- getFieldValue(ClientService.getDiskUsage_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- getFieldValue(ClientService.getInstanceId_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- getFieldValue(ClientService.getInstanceId_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- getFieldValue(ClientService.getNamespaceConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- getFieldValue(ClientService.getNamespaceConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- getFieldValue(ClientService.getRootTabletLocation_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- getFieldValue(ClientService.getRootTabletLocation_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- getFieldValue(ClientService.getTableConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- getFieldValue(ClientService.getTableConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- getFieldValue(ClientService.getUserAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- getFieldValue(ClientService.getUserAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- getFieldValue(ClientService.getZooKeepers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- getFieldValue(ClientService.getZooKeepers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- getFieldValue(ClientService.grantNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- getFieldValue(ClientService.grantNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- getFieldValue(ClientService.grantSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- getFieldValue(ClientService.grantSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- getFieldValue(ClientService.grantTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- getFieldValue(ClientService.grantTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- getFieldValue(ClientService.hasNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- getFieldValue(ClientService.hasNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- getFieldValue(ClientService.hasSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- getFieldValue(ClientService.hasSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- getFieldValue(ClientService.hasTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- getFieldValue(ClientService.hasTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- getFieldValue(ClientService.isActive_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- getFieldValue(ClientService.isActive_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- getFieldValue(ClientService.listLocalUsers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- getFieldValue(ClientService.listLocalUsers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- getFieldValue(ClientService.ping_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- getFieldValue(ClientService.ping_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- getFieldValue(ClientService.revokeNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- getFieldValue(ClientService.revokeNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- getFieldValue(ClientService.revokeSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- getFieldValue(ClientService.revokeSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- getFieldValue(ClientService.revokeTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- getFieldValue(ClientService.revokeTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- getFieldValue(TDiskUsage._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- getFieldValue(ThriftSecurityException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- getFieldValue(ThriftTableOperationException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- getFieldValue(ThriftTest.fails_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- getFieldValue(ThriftTest.fails_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- getFieldValue(ThriftTest.success_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- getFieldValue(ThriftTest.success_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- getFieldValue(ThriftTest.throwsError_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- getFieldValue(ThriftTest.throwsError_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- getFieldValue(InitialMultiScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- getFieldValue(InitialScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- getFieldValue(IterInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- getFieldValue(MapFileInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- getFieldValue(MultiScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getFieldValue(ScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- getFieldValue(TCMResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- getFieldValue(TColumn._Fields) - Method in class org.apache.accumulo.core.data.thrift.TColumn
- getFieldValue(TCondition._Fields) - Method in class org.apache.accumulo.core.data.thrift.TCondition
- getFieldValue(TConditionalMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- getFieldValue(TConditionalSession._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- getFieldValue(TConstraintViolationSummary._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- getFieldValue(TKey._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKey
- getFieldValue(TKeyExtent._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- getFieldValue(TKeyValue._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- getFieldValue(TMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getFieldValue(TRange._Fields) - Method in class org.apache.accumulo.core.data.thrift.TRange
- getFieldValue(UpdateErrors._Fields) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- getFieldValue(GcCycleStats._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- getFieldValue(GCMonitorService.getStatus_args._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- getFieldValue(GCMonitorService.getStatus_result._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- getFieldValue(GCStatus._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- getFieldValue(BulkImportStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- getFieldValue(Compacting._Fields) - Method in class org.apache.accumulo.core.master.thrift.Compacting
- getFieldValue(DeadServer._Fields) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- getFieldValue(FateService.beginFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- getFieldValue(FateService.beginFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- getFieldValue(FateService.executeFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getFieldValue(FateService.executeFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- getFieldValue(FateService.finishFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- getFieldValue(FateService.finishFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- getFieldValue(FateService.waitForFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- getFieldValue(FateService.waitForFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- getFieldValue(MasterClientService.drainReplicationTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- getFieldValue(MasterClientService.drainReplicationTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- getFieldValue(MasterClientService.getActiveTservers_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- getFieldValue(MasterClientService.getActiveTservers_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- getFieldValue(MasterClientService.getDelegationToken_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- getFieldValue(MasterClientService.getDelegationToken_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- getFieldValue(MasterClientService.getMasterStats_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- getFieldValue(MasterClientService.getMasterStats_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- getFieldValue(MasterClientService.initiateFlush_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- getFieldValue(MasterClientService.initiateFlush_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- getFieldValue(MasterClientService.removeNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- getFieldValue(MasterClientService.removeNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- getFieldValue(MasterClientService.removeSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- getFieldValue(MasterClientService.removeSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- getFieldValue(MasterClientService.removeTableProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- getFieldValue(MasterClientService.removeTableProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- getFieldValue(MasterClientService.reportSplitExtent_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- getFieldValue(MasterClientService.reportTabletStatus_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- getFieldValue(MasterClientService.setMasterGoalState_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- getFieldValue(MasterClientService.setMasterGoalState_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- getFieldValue(MasterClientService.setNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- getFieldValue(MasterClientService.setNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- getFieldValue(MasterClientService.setSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- getFieldValue(MasterClientService.setSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- getFieldValue(MasterClientService.setTableProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- getFieldValue(MasterClientService.setTableProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- getFieldValue(MasterClientService.shutdown_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- getFieldValue(MasterClientService.shutdown_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- getFieldValue(MasterClientService.shutdownTabletServer_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- getFieldValue(MasterClientService.shutdownTabletServer_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- getFieldValue(MasterClientService.waitForBalance_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- getFieldValue(MasterClientService.waitForBalance_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
- getFieldValue(MasterClientService.waitForFlush_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- getFieldValue(MasterClientService.waitForFlush_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- getFieldValue(MasterMonitorInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getFieldValue(RecoveryException._Fields) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- getFieldValue(RecoveryStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- getFieldValue(TableInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getFieldValue(TabletServerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getFieldValue(TabletSplit._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- getFieldValue(KeyValues._Fields) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- getFieldValue(RemoteReplicationException._Fields) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- getFieldValue(ReplicationCoordinator.getServicerAddress_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- getFieldValue(ReplicationCoordinator.getServicerAddress_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- getFieldValue(ReplicationCoordinatorException._Fields) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- getFieldValue(ReplicationServicer.replicateKeyValues_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- getFieldValue(ReplicationServicer.replicateKeyValues_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- getFieldValue(ReplicationServicer.replicateLog_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- getFieldValue(ReplicationServicer.replicateLog_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- getFieldValue(WalEdits._Fields) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- getFieldValue(TAuthenticationKey._Fields) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- getFieldValue(TAuthenticationTokenIdentifier._Fields) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- getFieldValue(TCredentials._Fields) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- getFieldValue(TDelegationToken._Fields) - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- getFieldValue(TDelegationTokenConfig._Fields) - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- getFieldValue(ActionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getFieldValue(ActiveCompaction._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getFieldValue(ActiveScan._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getFieldValue(ConstraintViolationException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- getFieldValue(IteratorConfig._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- getFieldValue(NoSuchScanIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
- getFieldValue(NotServingTabletException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- getFieldValue(TabletClientService.applyUpdates_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- getFieldValue(TabletClientService.bulkImport_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- getFieldValue(TabletClientService.bulkImport_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- getFieldValue(TabletClientService.chop_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- getFieldValue(TabletClientService.closeConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- getFieldValue(TabletClientService.closeMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- getFieldValue(TabletClientService.closeMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- getFieldValue(TabletClientService.closeScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- getFieldValue(TabletClientService.closeUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- getFieldValue(TabletClientService.closeUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- getFieldValue(TabletClientService.compact_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- getFieldValue(TabletClientService.conditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- getFieldValue(TabletClientService.conditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- getFieldValue(TabletClientService.continueMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- getFieldValue(TabletClientService.continueMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- getFieldValue(TabletClientService.continueScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- getFieldValue(TabletClientService.continueScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- getFieldValue(TabletClientService.fastHalt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- getFieldValue(TabletClientService.flush_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- getFieldValue(TabletClientService.flushTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- getFieldValue(TabletClientService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- getFieldValue(TabletClientService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- getFieldValue(TabletClientService.getActiveLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- getFieldValue(TabletClientService.getActiveLogs_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- getFieldValue(TabletClientService.getActiveScans_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- getFieldValue(TabletClientService.getActiveScans_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- getFieldValue(TabletClientService.getHistoricalStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- getFieldValue(TabletClientService.getHistoricalStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- getFieldValue(TabletClientService.getTabletServerStatus_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- getFieldValue(TabletClientService.getTabletServerStatus_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- getFieldValue(TabletClientService.getTabletStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- getFieldValue(TabletClientService.getTabletStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- getFieldValue(TabletClientService.halt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- getFieldValue(TabletClientService.halt_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- getFieldValue(TabletClientService.invalidateConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- getFieldValue(TabletClientService.invalidateConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- getFieldValue(TabletClientService.loadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- getFieldValue(TabletClientService.removeLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- getFieldValue(TabletClientService.splitTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- getFieldValue(TabletClientService.splitTablet_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- getFieldValue(TabletClientService.startConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getFieldValue(TabletClientService.startConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- getFieldValue(TabletClientService.startMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getFieldValue(TabletClientService.startMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- getFieldValue(TabletClientService.startScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getFieldValue(TabletClientService.startScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- getFieldValue(TabletClientService.startUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- getFieldValue(TabletClientService.startUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- getFieldValue(TabletClientService.unloadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- getFieldValue(TabletClientService.update_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- getFieldValue(TabletClientService.update_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- getFieldValue(TabletStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getFieldValue(TIteratorSetting._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- getFieldValue(TooManyFilesException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- getFieldValue(TSampleNotPresentException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- getFieldValue(TSamplerConfiguration._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- getFieldValue(TInfo._Fields) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- getFile(Key) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
- getFile(Key, Text) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
-
Extract the file name from the row suffix into the given
Text
- getFile(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
- getFile(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.StatusSection
-
Extract the file name from the row suffix into the given
Text
- getFile(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.WorkSection
- getFileLenCache() - Method in class org.apache.accumulo.core.file.FileOperations.FileReaderOperation
- getFilename() - Method in class org.apache.accumulo.core.file.FileOperations.FileAccessOperation
- getFilename() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- getFilenames() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- getFilenamesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- getFilenamesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- getFiles() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- getFilesIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getFileSize() - Method in class org.apache.accumulo.core.file.FileOperations
-
Construct an operation object allowing one to query the size of a file.
- getFileSize(FileOperations.GetFileSizeOperation) - Method in class org.apache.accumulo.core.file.FileOperations
- getFileSize(FileOperations.GetFileSizeOperation) - Method in class org.apache.accumulo.core.file.map.MapFileOperations
- getFileSize(FileOperations.GetFileSizeOperation) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
- GetFileSizeOperation() - Constructor for class org.apache.accumulo.core.file.FileOperations.GetFileSizeOperation
- getFilesSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- getFileSystem() - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- getFileSystem() - Method in class org.apache.accumulo.core.file.FileOperations.FileAccessOperation
- getFileSystem() - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
- getFileSystem() - Method in interface org.apache.accumulo.core.volume.Volume
-
A
FileSystem
that Accumulo will use - getFileSystem() - Method in class org.apache.accumulo.core.volume.VolumeImpl
- getFinished() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- getFirst() - Method in class org.apache.accumulo.core.util.Pair
- getFirstKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- getFirstKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
- getFirstKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- getFirstKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- getFirstKey() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- getFirstKey() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- getFloat(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
- getFloat(String, float) - 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
- getFloat(String, Float) - 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
- getFlush() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
- getFlushID() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- getFlushs() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getFormatter(Class<? extends Formatter>, Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
- getFraction(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Interprets a string specifying a fraction.
- getFraction(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property of type
PropertyType.FRACTION
, interpreting the value properly. - getFreeSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Get the current size of this cache.
- getFromHadoopCredentialProvider(Configuration, String) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- getFullScans() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getFullScansIterator() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getFullScansSize() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getGoal() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- getGoalState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getHadoopConfiguration() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
- getHistoricalStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
- getHistoricalStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
- getHistoricalStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- getHistoricalStats(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- getHistoricalStats(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- getHistoricalStats(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- getHistoricalStats_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- getHistoricalStats_args(TabletClientService.getHistoricalStats_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
-
Performs a deep copy on other.
- getHistoricalStats_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- getHistoricalStats_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getHistoricalStats_call
- getHistoricalStats_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- getHistoricalStats_result(TabletClientService.getHistoricalStats_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
-
Performs a deep copy on other.
- getHistoricalStats_result(TabletStats, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- getHitCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- getHitRatio() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- getHoldTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getHost() - Method in class org.apache.accumulo.core.util.HostAndPort
-
Returns the portion of this
HostAndPort
instance that should represent the hostname or IPv4/IPv6 literal. - getId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- getId() - Method in enum org.apache.accumulo.core.security.NamespacePermission
-
Gets the byte ID of this permission.
- getId() - Method in enum org.apache.accumulo.core.security.SystemPermission
-
Gets the byte ID of this permission.
- getId() - Method in enum org.apache.accumulo.core.security.TablePermission
-
Gets the byte ID of this permission.
- getIdentifier() - Method in class org.apache.accumulo.core.client.impl.DelegationTokenImpl
-
The identifier for this token, may be null.
- getIdentifier() - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- getIdleTime() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getIdleTime() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getIdleTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getIdtoNameMap() - Method in class org.apache.accumulo.core.client.impl.TableMap
- getIdToNameMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
- getIdToNameMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
- getIndex() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- getIndex() - Method in interface org.apache.accumulo.core.file.blockfile.cache.CacheEntry
- getIndex() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- getIndex(Class<T>) - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
- getIndex(Class<T>) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
- getIndex(Class<T>) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
- getIndex(ABlockReader, MultiLevelIndex.IndexEntry) - Static method in class org.apache.accumulo.core.file.rfile.BlockIndex
- getIndexCache() - Method in class org.apache.accumulo.core.file.FileOperations.FileReaderOperation
- getIndexCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getIndexCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getIndexInfo(Map<Integer, Long>, Map<Integer, Long>) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
- getIngestByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getIngestRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getIngestRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getInitializationVector() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the initialization vector to use for this crypto module.
- getInMemoryConfiguration() - 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
- getInputFiles() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getInputFiles() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getInputFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getInputFilesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getInputFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getInputStream() - Method in class org.apache.accumulo.core.client.rfile.RFileSource
- getInputTableConfig(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Returns the
InputTableConfig
for the given table - getInputTableConfig(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Fetches a
InputTableConfig
that has been set on the configuration for a specific table. - getInputTableConfig(JobContext, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Fetches a
InputTableConfig
that has been set on the configuration for a specific table. - getInputTableConfigs(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Returns all
InputTableConfig
objects associated with this job. - getInputTableConfigs(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Fetches all
InputTableConfig
s that have been set on the given Hadoop job. - getInputTableConfigs(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Fetches all
InputTableConfig
s that have been set on the given job. - getInputTableName(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Sets the name of the input table, over which this job will scan.
- getInputTableName(Class<?>, Configuration) - 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.
- getInputTableName(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Gets the table name from the configuration.
- getInputTableName(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Gets the table name from the configuration.
- getInstance() - Method in class org.apache.accumulo.core.cli.ClientOpts
- getInstance() - Method in class org.apache.accumulo.core.client.Connector
-
Accessor method for internal instance object.
- getInstance() - Method in class org.apache.accumulo.core.client.impl.ClientContext
-
Retrieve the instance used to construct this context
- getInstance() - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
- getInstance() - Static method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
- getInstance() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
-
Deprecated.since 1.7.0, use getInstance(ClientConfiguration) instead.
- getInstance() - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- getInstance() - Static method in class org.apache.accumulo.core.conf.DefaultConfiguration
-
Gets a default configuration.
- getInstance() - Static method in class org.apache.accumulo.core.conf.SiteConfiguration
-
Gets an instance of this class.
- getInstance() - Static method in class org.apache.accumulo.core.file.FileOperations
- getInstance() - Static method in class org.apache.accumulo.core.util.CachedConfiguration
- getInstance() - Static method in class org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory
-
Get the singleton instance of the SharedRateLimiterFactory.
- getInstance(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Initializes an Accumulo
Instance
based on the configuration. - getInstance(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- getInstance(ClientConfiguration) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getInstance(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Initializes an Accumulo
Instance
based on the configuration. - getInstance(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Initializes an Accumulo
Instance
based on the configuration. - getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Initializes an Accumulo
Instance
based on the configuration. - getInstance(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Initializes an Accumulo
Instance
based on the configuration. - getInstanceId() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
- getInstanceId() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
- getInstanceId() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- getInstanceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- getInstanceId() - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- getInstanceId() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- getInstanceId() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- getInstanceId(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- getInstanceId(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- getInstanceID() - Method in interface org.apache.accumulo.core.client.Instance
-
Returns a unique string that identifies this instance of accumulo.
- getInstanceID() - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getInstanceID() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
- getInstanceId_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- getInstanceId_args(ClientService.getInstanceId_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
-
Performs a deep copy on other.
- getInstanceId_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getInstanceId_call
- getInstanceId_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- getInstanceId_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- getInstanceId_result(ClientService.getInstanceId_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
-
Performs a deep copy on other.
- getInstanceIDFromHdfs(Path, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
-
Utility to support certain client side utilities to minimize command-line options.
- getInstanceIDFromHdfs(Path, AccumuloConfiguration, Configuration) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
- getInstanceName() - Method in interface org.apache.accumulo.core.client.Instance
-
Returns the instance name given at system initialization time.
- getInstanceName() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getInstanceName() - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getInstanceName() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
- getInt(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
- getInt(String, int) - 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
- getInteger(String, Integer) - 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
- getInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- getInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- getInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- getInterpolator() - 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
- getInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- getIssueDate() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- getIssueDate() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- getIterator() - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
- getIteratorClass() - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Get the name of the class that implements the iterator.
- getIteratorClass() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- getIterators() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getIterators() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
- getIterators() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getIterators() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
-
Returns the iterators to be set on this configuration
- getIterators() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getIterators() - Method in class org.apache.accumulo.core.data.Condition
-
Gets the iterators for this condition.
- getIterators() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- getIterators() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- getIterators(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
- getIterators(Class<?>, Configuration) - 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.
- getIterators(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
- getIterators(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Gets a list of the iterator settings (for iterators to apply to a scanner) from this configuration.
- getIteratorSamplerConfiguration() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
- getIteratorScope() - Method in class org.apache.accumulo.core.client.impl.BaseIteratorEnvironment
- getIteratorScope() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
- getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Get the settings for an iterator.
- getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Get the settings for an iterator.
- getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
- getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
- getIteratorsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- getIteratorsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- getIterName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- getKerberosServerPrimary() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
-
The 'primary' component from the Kerberos principals that servers are configured to use.
- getKey() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- getKey() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
- getKey() - Method in enum org.apache.accumulo.core.conf.Property
-
Gets the key (string) for this property.
- getKey() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- getKey() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- getKey() - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
- getKeyEncryptionStrategyClass() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the key encryption strategy class.
- getKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- getKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- getKeyExtentsForRange(Text, Text, Set<KeyExtent>) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
-
Deprecated.this method not intended for public use and is likely to be removed in a future version.
- getKeyExtentsForRange(Text, Text, Set<KeyExtent>) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.this method not intended for public use and is likely to be removed in a future version.
- getKeyId() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- getKeyId() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- getKeyId() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- getKeyLength() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the length of the secret key.
- getKeyPrefix() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Indicates the prefix of keys that will be transformed by this iterator.
- getKeys() - Method in class org.apache.accumulo.core.client.ClientConfiguration
- getKeys(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
- getKeys(Configuration) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Attempt to extract all aliases from any configured CredentialsProviders.
- getKeyStorePass() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getKeyStorePath() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getKeyStoreType() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getKeytab() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
-
The keytab file used to perform Kerberos login.
- getKeyValues() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- getKeyValuesIterator() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- getKeyValuesSize() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- getKind() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- getKVCount() - Method in class org.apache.accumulo.core.client.RowIterator
-
Get a count of the total number of entries in all rows read so far.
- getLast() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- getLastColumnFamilies() - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroupSeekCache
- getLastContact() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getLastContactTime() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getLastContactTime() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getLastKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- getLastKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
- getLastKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- getLastKey() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
- getLastKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- getLastKey() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- getLastKey() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- getLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- getLastStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- getLastUsed() - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroupSeekCache
- getLength() - Method in class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
-
This implementation of length is only an estimate, it does not provide exact values.
- getLength() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
-
This implementation of length is only an estimate, it does not provide exact values.
- getLength() - Method in class org.apache.accumulo.core.client.rfile.RFileSource
- getLength() - Method in class org.apache.accumulo.core.data.ComparableBytes
-
Deprecated.
- getLength() - Method in class org.apache.accumulo.core.data.impl.ComparableBytes
- getLength() - Method in class org.apache.accumulo.core.data.Key
-
Returns the sums of the lengths of the row, column family, column qualifier, and column visibility.
- getLength() - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileWriter
- getLength() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Writer
- getLength() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
- getLength() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
- getLength() - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
- getLifetime() - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- getList() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
-
Get a sorted List of all elements in this queue, in descending order.
- getList(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
- getList(String, List) - 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
- getListDelimiter() - 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
- getLoadLock(String) - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
-
Return a lock used for loading data not in the cache.
- getLoadLock(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
- getLocalCacheFiles(Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.DistributedCacheHelper
- getLocalityGroup() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getLocalityGroup() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getLocalityGroup() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getLocalityGroupCF() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- getLocalityGroups() - Method in class org.apache.accumulo.core.client.mock.MockTable
-
Deprecated.
- getLocalityGroups(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Gets the locality groups currently set for a table.
- getLocalityGroups(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- getLocalityGroups(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
- getLocalityGroupsIgnoringErrors(AccumuloConfiguration, String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
- getLocation(Instance) - Static method in class org.apache.accumulo.core.util.MonitorUtil
- getLocationless() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocations
- getLocations() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocations
- getLocations() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getLocator(ClientContext, String) - Static method in class org.apache.accumulo.core.client.impl.TabletLocator
- getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- getLogger() - 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
- getLogLevel() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getLogLevel(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Gets the log level from this configuration.
- getLogLevel(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- getLogLevel(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Gets the log level from this configuration.
- getLogLevel(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Gets the log level from this configuration.
- getLogLevel(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Gets the log level from this configuration.
- getLogLevel(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Gets the log level from this configuration.
- getLogSorts() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getLogSortsIterator() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getLogSortsSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getLogsToWatch() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- getLogsToWatchIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- getLogsToWatchSize() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- getLong(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
- getLong(String, long) - 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
- getLong(String, Long) - 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
- getLookups() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getMajor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
-
Get the major version.
- getMajors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getMajors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getMask() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
- getMasterDrain(TInfo, TCredentials, String, Set<String>) - Method in class org.apache.accumulo.core.client.impl.ReplicationOperationsImpl
- getMasterLocations() - Method in interface org.apache.accumulo.core.client.Instance
-
Returns the location(s) of the accumulo master and any redundant servers.
- getMasterLocations() - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getMasterLocations() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
- getMasterStats() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
- getMasterStats() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getMasterStats
- getMasterStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
- getMasterStats(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
- getMasterStats(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
- getMasterStats(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
- getMasterStats_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- getMasterStats_args(MasterClientService.getMasterStats_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
-
Performs a deep copy on other.
- getMasterStats_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- getMasterStats_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getMasterStats_call
- getMasterStats_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- getMasterStats_result(MasterClientService.getMasterStats_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
-
Performs a deep copy on other.
- getMasterStats_result(MasterMonitorInfo, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- getMax() - Method in class org.apache.accumulo.core.util.Stat
- getMaxFilesPerTablet() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets the maximum number of files per tablet from this configuration.
- getMaxLatency(TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
- getMaxLoops() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- getMaxMemory() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
- getMaxRow(String, Authorizations, Text, boolean, Text, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Finds the max row within a given range.
- getMaxRow(String, Authorizations, Text, boolean, Text, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- getMaxSize() - Method in interface org.apache.accumulo.core.file.blockfile.cache.BlockCache
-
Get the maximum size of this cache.
- getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
- getMaxWriteThreads() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
- getMaxWriteThreads() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
- getMechanism() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
-
The SASL mechanism to use for authentication
- getMechanismName() - Method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
- getMemoryInBytes(String) - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Interprets a string specifying a memory size.
- getMemoryInBytes(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property of type
PropertyType.MEMORY
, interpreting the value properly. - getMessage() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
- getMessage() - Method in exception org.apache.accumulo.core.security.VisibilityParseException
- getMetaBlock(long, long, long) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
- getMetaBlock(long, long, long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
- getMetaBlock(String) - Method in interface org.apache.accumulo.core.file.blockfile.BlockFileReader
- getMetaBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
-
It is intended that once the BlockRead object is returned to the caller, that the caller will read the entire block and then call close on the BlockRead class.
- getMetaBlock(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
-
Stream access to a Meta Block.
- getMetadataEntry() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
-
Returns a String representing this extent's entry in the Metadata table
- getMetadataEntry() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getMetadataEntry(String, Text) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- getMetadataEntry(KeyExtent) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- getMetadataEntry(KeyExtent) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getMetadataEntry(Text, Text) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getMetadataLocationEntries(SortedMap<Key, Value>) - Static method in class org.apache.accumulo.core.metadata.MetadataLocationObtainer
- getMetaStore(String) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- getMetaStore(String) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
- getMetaStore(String) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- getMetaStore(String) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- getMetaStore(String) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- getMetaStore(String) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- getMetrics() - Method in interface org.apache.accumulo.core.file.rfile.MetricsGatherer
- getMetrics() - Method in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
- getMin() - Method in class org.apache.accumulo.core.util.Stat
- getMinor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
-
Get the minor version.
- getMinors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getMinors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getMissCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- getMissRatio() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- getMutation() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
- getMutation() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- getMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- getMutations() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletServerMutations
- getMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- getMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- getMutationsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- getMutationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- getMutationsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- getName() - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Get the iterator's name.
- getName() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- getName() - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- getName() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
- getName() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- getName() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getName() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
- getName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- getNamedOptions() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
- getNamespace() - Method in class org.apache.accumulo.core.client.mock.MockTable
-
Deprecated.
- getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
- getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
- getNamespaceConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- getNamespaceConfiguration(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- getNamespaceConfiguration(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- getNamespaceConfiguration(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- getNamespaceConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- getNamespaceConfiguration_args(ClientService.getNamespaceConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
Performs a deep copy on other.
- getNamespaceConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- getNamespaceConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
- getNamespaceConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- getNamespaceConfiguration_result(Map<String, String>, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- getNamespaceConfiguration_result(ClientService.getNamespaceConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
Performs a deep copy on other.
- getNamespaceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- getNamespaceId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
- getNamespaceId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
-
Returns the namespace id for a given table ID.
- getNamespaceName() - Method in class org.apache.accumulo.core.client.mock.MockTable
-
Deprecated.
- getNamespaceName() - Method in exception org.apache.accumulo.core.client.NamespaceNotEmptyException
- getNamespaceName() - Method in exception org.apache.accumulo.core.client.NamespaceNotFoundException
- getNamespaceName(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
- getNameToIdMap() - Method in class org.apache.accumulo.core.client.impl.TableMap
- getNameToIdMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
- getNameToIdMap(Instance) - Static method in class org.apache.accumulo.core.client.impl.Tables
- getNewDataSource() - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
- getNewFileExtension(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.FileOperations
- getNewTablets() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- getNewTabletsIterator() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- getNewTabletsSize() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- getNextKeyHint(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
- getNextKeyHint(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
-
Whenever the subclass returns AdvanceResult.USE_HINT from its filter predicate, this method will be called to see how far to advance the source iterator.
- getNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- getNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- getNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- getNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- getNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- getNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- getNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- getNum() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getNumberOfConfigurations() - 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
- getNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
- getNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- getNumEntries() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- getNumEntries() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- getNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getNumLGSeeked() - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroupSeekCache
- getObject(Key) - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
- getObservers() - Method in class org.apache.accumulo.core.conf.ObservableConfiguration
-
Gets the current set of observers.
- getOffset() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- getOldTablet() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- getOnlineTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getOp() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- getOp() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getOpaqueKeyEncryptionKeyID() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the opaque ID associated with the encrypted version of the plaintext key.
- getOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- getOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- getOptions() - Method in class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
- getOptions() - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Get the configuration parameters for this iterator.
- getOptions() - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
- getOptions() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getOptions() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
- getOptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- getOptionsSize() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getOptionsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- getOsLoad() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getOutputCommitter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
- getOutputFile() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getOutputFile() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getOutputStream() - Method in class org.apache.accumulo.core.file.FileOperations.OpenWriterOperation
- getOverrideStreamsSecretKeyEncryptionStrategy() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the flag that indicates if the underlying stream's key encryption strategy should be overridden by the currently configured key encryption strategy.
- getPadding() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the name of the padding type to use for encryption.
- getParentId() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- getParseTree() - Method in class org.apache.accumulo.core.security.ColumnVisibility
-
Gets the parse tree for this column visibility.
- getPartition(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- getPartition(Key, Writable, int) - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
- getPartition(Text, Writable, int) - Method in class org.apache.accumulo.core.client.mapreduce.lib.partition.RangePartitioner
- getPartNextKey() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getPartScan() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getPassword() - Method in class org.apache.accumulo.core.cli.ClientOpts
- getPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- getPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- getPassword() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
- getPassword() - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- getPassword(SecretManager<T>, T) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
-
Generate the password from the provided
SecretManager
andTokenIdentifier
. - getPath(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property of type
PropertyType.PATH
, interpreting the value properly, replacing supported environment variables. - getPeerName() - Method in class org.apache.accumulo.core.replication.ReplicationTarget
- getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- getPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
-
Gets the permission matching the given byte ID.
- getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.SystemPermission
-
Gets the permission matching the given byte ID.
- getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.TablePermission
-
Gets the permission matching the given byte ID.
- getPlaintextInputStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the plaintext input stream, which is nearly always a wrapped version of the output from
CryptoModuleParameters.getEncryptedInputStream()
. - getPlaintextKey() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the plaintext secret key.
- getPlaintextOutputStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the plaintext output stream to wrap for encryption.
- getPort() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
- getPort() - Method in class org.apache.accumulo.core.util.HostAndPort
-
Get the current port number, failing if no port is defined.
- getPort(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property of type
PropertyType.PORT
, interpreting the value properly (as an integer within the range of non-privileged ports). - getPos() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
- getPos() - Method in class org.apache.accumulo.core.file.streams.RateLimitedInputStream
- getPos() - Method in class org.apache.accumulo.core.file.streams.SeekableDataInputStream
- getPosition() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
-
Get the file position.
- getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
- getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
- getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
- getPositionAndReset() - Method in class org.apache.accumulo.core.iterators.YieldCallback
-
Called by the client to get the yield position used as the start key (non-inclusive) of the range in a subsequent seek call when the iterator is rebuilt.
- getPrevEndRow() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
-
Return the previous extent's end row
- getPrevEndRow() - Method in class org.apache.accumulo.core.data.impl.TabletIdImpl
- getPrevEndRow() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getPrevEndRow() - Method in interface org.apache.accumulo.core.data.TabletId
- getPrevEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- getPrevKey() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
- getPrevRowUpdateMutation() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
-
Returns a String representing the previous extent's entry in the Metadata table
- getPrevRowUpdateMutation() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getPrevRowUpdateMutation(KeyExtent) - Static method in class org.apache.accumulo.core.data.impl.KeyExtent
- getPrevRowUpdateMutation(KeyExtent) - Static method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getPrincipal() - Method in class org.apache.accumulo.core.cli.ClientOpts
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.Credentials
-
Gets the principal.
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- getPrincipal() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getPrincipal() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
-
The identity of the user to which this token belongs to according to Kerberos
- getPrincipal() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
-
The principal of the logged in user for SASL
- getPrincipal() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- getPrincipal() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- getPrincipal(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Gets the user name from the configuration.
- getPrincipal(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- getPrincipal(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Gets the user name from the configuration.
- getPrincipal(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Gets the principal from the configuration.
- getPrincipal(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Gets the user name from the configuration.
- getPrincipal(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Gets the user name from the configuration.
- getPrintableTableInfoFromId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
- getPrintableTableInfoFromName(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
- getPrintableTableNameFromId(Map<String, String>, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
- getPriority() - Method in class org.apache.accumulo.core.client.IteratorSetting
-
Get layer at which this iterator applies.
- getPriority() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- getPriority() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- getPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- getProgress() - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
- getProgress() - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
- getProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- getProgress(ByteSequence, ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.client.mapreduce.impl.SplitUtils
- getProgress(ByteSequence, ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getProgress(Key) - Method in class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
-
Save progress on each call to this function, implied by value of currentKey, and return average ranges in the split
- getProgress(Key) - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getProperties() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
-
Retrieves the complete set of currently configured table properties to be applied to a table when this configuration object is used.
- getProperties() - Method in class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- getProperties() - Method in class org.apache.accumulo.core.client.mapreduce.impl.DelegationTokenStub
- getProperties() - Method in interface org.apache.accumulo.core.client.security.tokens.AuthenticationToken
- getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
- getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
- getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
- getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
- getProperties() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- getProperties(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Gets properties of a namespace, which are inherited by tables in this namespace.
- getProperties(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Gets properties of a table.
- getProperties(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
- getProperties(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
- getProperties(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- getProperties(String, Properties) - 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
- getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Returns property key/value pairs in this configuration.
- getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
- getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
- getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
- getProperties(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.rpc.SaslConnectionParams
- getPropertiesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- getPropertiesToExclude() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
-
The source table properties are copied, this allows reverting to system defaults for some of those properties.
- getPropertiesToExclude() - Method in class org.apache.accumulo.core.client.impl.CloneConfigurationImpl
- getPropertiesToSet() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
-
The source table properties are copied.
- getPropertiesToSet() - Method in class org.apache.accumulo.core.client.impl.CloneConfigurationImpl
- getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- getProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- getProperty(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
- getProperty(IteratorUtil.IteratorScope) - Static method in enum org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
-
Deprecated.since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to discourage its use.
- getPropertyByKey(String) - Static method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- getPropertyByKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
-
Gets a
Property
instance with the given key. - getProtocol(TTransport) - Method in class org.apache.accumulo.core.rpc.TraceProtocolFactory
- getQualifier() - Method in class org.apache.accumulo.core.data.Condition
-
Gets the column qualifier of this condition.
- getQuality() - Method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
- getQualityOfProtection() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
-
The quality of protection used with SASL.
- getQueryByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getQueryRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getQueryRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getQueued() - Method in class org.apache.accumulo.core.master.thrift.Compacting
- getQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getRandomNumberGenerator() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the random number generator name.
- getRandomNumberGeneratorProvider() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the random number generator provider name.
- getRange() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
- getRange() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
- getRange() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
- getRange() - Method in class org.apache.accumulo.core.client.IsolatedScanner
- getRange() - Method in class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
- getRange() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getRange() - Method in class org.apache.accumulo.core.client.mock.MockScanner
-
Deprecated.
- getRange() - Method in interface org.apache.accumulo.core.client.Scanner
-
Returns the range of keys to scan over.
- getRange() - Method in class org.apache.accumulo.core.file.FileOperations.OpenScanReaderOperation
-
The range over which this reader should scan.
- getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
- getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
- getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
- getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
- getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
- getRange() - Method in class org.apache.accumulo.core.schema.Section
- getRange() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getRange(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
- getRangeLength(Range) - Static method in class org.apache.accumulo.core.client.mapreduce.impl.SplitUtils
- getRanges() - Method in class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
- getRanges() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
-
Returns the ranges to be queried in the configuration
- getRanges(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Gets the ranges to scan over from a job.
- getRanges(Class<?>, Configuration) - 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.
- getRanges(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Gets the ranges to scan over from a job.
- getRanges(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Gets the ranges to scan over from a job.
- getRate() - Method in class org.apache.accumulo.core.util.ratelimit.GuavaRateLimiter
- getRate() - Method in class org.apache.accumulo.core.util.ratelimit.NullRateLimiter
- getRate() - Method in interface org.apache.accumulo.core.util.ratelimit.RateLimiter
-
Get current QPS of the rate limiter, with a nonpositive rate indicating no limit.
- getRateLimiter() - Method in class org.apache.accumulo.core.file.FileOperations.FileIOOperation
- getRawDefaultValue() - Method in enum org.apache.accumulo.core.conf.Property
-
Gets the default value for this property exactly as provided in its definition (i.e., without interpolation or conversion to absolute paths).
- getRawSize() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
- getRawSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
- getRawSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
-
Get the uncompressed size of the block.
- getRawSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
-
Get the raw size of the block.
- getRawSize() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
- getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
- getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
- getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.IsolatedScanner
- getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.mock.MockScanner
-
Deprecated.
- getReadaheadThreshold() - Method in interface org.apache.accumulo.core.client.Scanner
-
The number of batches of Key/Value pairs returned before the
Scanner
will begin to prefetch the next batch - getReadaheadThreshold() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getReason() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getReason() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getReason() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- getReason() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- getReason() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getReconnectionDelay() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
- getRecordParametersToStream() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the flag that indicates whether or not the module should record its cryptographic parameters to the stream automatically, or rely on the calling code to do so.
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloInputFormat
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloMultiTableInputFormat
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class org.apache.accumulo.core.client.mapred.AccumuloRowInputFormat
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
- getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
- getRecordWriter(TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
- getRecs() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getRecsInMemory() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getRemoteHost() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
- getRemoteIdentifier() - Method in class org.apache.accumulo.core.replication.ReplicationTarget
- getRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- getRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- getRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- getReplicationSources() - Method in class org.apache.accumulo.core.data.Mutation
-
Return the replication sources for this Mutation
- getRequestCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- getRequestTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- getResponseTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticate_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.authenticateUser_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.bulkImportFiles_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeAuthorizations_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkClass_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.checkTableClass_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.createLocalUser_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.dropLocalUser_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getConfiguration_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getDiskUsage_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getInstanceId_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getTableConfiguration_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getZooKeepers_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantSystemPermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantTablePermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasSystemPermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasTablePermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.isActive_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.listLocalUsers_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.ping_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.revokeTablePermission_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.fails_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.success_call
- getResult() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncClient.throwsError_call
- getResult() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- getResult() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- getResult() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.beginFateOperation_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.executeFateOperation_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.finishFateOperation_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncClient.waitForFateOperation_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.drainReplicationTable_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getActiveTservers_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getDelegationToken_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.getMasterStats_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.initiateFlush_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeNamespaceProperty_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeSystemProperty_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.removeTableProperty_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.reportSplitExtent_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.reportTabletStatus_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setMasterGoalState_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setNamespaceProperty_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setSystemProperty_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.setTableProperty_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.shutdown_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.shutdownTabletServer_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.waitForBalance_call
- getResult() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.waitForFlush_call
- getResult() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient.getServicerAddress_call
- getResult() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient.replicateKeyValues_call
- getResult() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncClient.replicateLog_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.applyUpdates_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.bulkImport_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.chop_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeConditionalUpdate_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeMultiScan_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeScan_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.closeUpdate_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.compact_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.conditionalUpdate_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueMultiScan_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.continueScan_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.fastHalt_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flush_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.flushTablet_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveCompactions_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveLogs_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getActiveScans_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getHistoricalStats_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletServerStatus_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletStats_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.halt_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.invalidateConditionalUpdate_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.loadTablet_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.removeLogs_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.splitTablet_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startConditionalUpdate_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startMultiScan_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startScan_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.startUpdate_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.unloadTablet_call
- getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.update_call
- getResult(I, ClientService.authenticate_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
- getResult(I, ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
- getResult(I, ClientService.bulkImportFiles_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
- getResult(I, ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
- getResult(I, ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeLocalUserPassword
- getResult(I, ClientService.checkClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
- getResult(I, ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
- getResult(I, ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
- getResult(I, ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
- getResult(I, ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
- getResult(I, ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
- getResult(I, ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
- getResult(I, ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
- getResult(I, ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
- getResult(I, ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
- getResult(I, ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
- getResult(I, ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
- getResult(I, ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
- getResult(I, ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
- getResult(I, ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
- getResult(I, ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
- getResult(I, ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
- getResult(I, ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
- getResult(I, ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
- getResult(I, ClientService.isActive_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
- getResult(I, ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
- getResult(I, ClientService.ping_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ping
- getResult(I, ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeNamespacePermission
- getResult(I, ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeSystemPermission
- getResult(I, ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeTablePermission
- getResult(I, ThriftTest.fails_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.fails
- getResult(I, ThriftTest.success_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.success
- getResult(I, ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.throwsError
- getResult(I, GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
- getResult(I, FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.beginFateOperation
- getResult(I, FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.executeFateOperation
- getResult(I, FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.finishFateOperation
- getResult(I, FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.waitForFateOperation
- getResult(I, MasterClientService.drainReplicationTable_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.drainReplicationTable
- getResult(I, MasterClientService.getActiveTservers_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getActiveTservers
- getResult(I, MasterClientService.getDelegationToken_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getDelegationToken
- getResult(I, MasterClientService.getMasterStats_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getMasterStats
- getResult(I, MasterClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.initiateFlush
- getResult(I, MasterClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeNamespaceProperty
- getResult(I, MasterClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeSystemProperty
- getResult(I, MasterClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeTableProperty
- getResult(I, MasterClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportSplitExtent
- getResult(I, MasterClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportTabletStatus
- getResult(I, MasterClientService.setMasterGoalState_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setMasterGoalState
- getResult(I, MasterClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setNamespaceProperty
- getResult(I, MasterClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setSystemProperty
- getResult(I, MasterClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setTableProperty
- getResult(I, MasterClientService.shutdown_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdown
- getResult(I, MasterClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdownTabletServer
- getResult(I, MasterClientService.waitForBalance_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForBalance
- getResult(I, MasterClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForFlush
- getResult(I, ReplicationCoordinator.getServicerAddress_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Processor.getServicerAddress
- getResult(I, ReplicationServicer.replicateKeyValues_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateKeyValues
- getResult(I, ReplicationServicer.replicateLog_args) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateLog
- getResult(I, TabletClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
- getResult(I, TabletClientService.bulkImport_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
- getResult(I, TabletClientService.chop_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
- getResult(I, TabletClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
- getResult(I, TabletClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeMultiScan
- getResult(I, TabletClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeScan
- getResult(I, TabletClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
- getResult(I, TabletClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
- getResult(I, TabletClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
- getResult(I, TabletClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueMultiScan
- getResult(I, TabletClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueScan
- getResult(I, TabletClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
- getResult(I, TabletClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
- getResult(I, TabletClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
- getResult(I, TabletClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
- getResult(I, TabletClientService.getActiveLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveLogs
- getResult(I, TabletClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveScans
- getResult(I, TabletClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
- getResult(I, TabletClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
- getResult(I, TabletClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
- getResult(I, TabletClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
- getResult(I, TabletClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
- getResult(I, TabletClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
- getResult(I, TabletClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
- getResult(I, TabletClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
- getResult(I, TabletClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
- getResult(I, TabletClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startMultiScan
- getResult(I, TabletClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startScan
- getResult(I, TabletClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
- getResult(I, TabletClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
- getResult(I, TabletClientService.update_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.success
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.throwsError
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.beginFateOperation
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.waitForFateOperation
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.drainReplicationTable
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getActiveTservers
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getDelegationToken
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeNamespaceProperty
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeSystemProperty
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeTableProperty
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportSplitExtent
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportTabletStatus
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setMasterGoalState
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setNamespaceProperty
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setSystemProperty
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setTableProperty
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdown
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdownTabletServer
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForBalance
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForFlush
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor.getServicerAddress
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateKeyValues
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateLog
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveLogs
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startMultiScan
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startScan
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
- getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
- getResults() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getResults() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- getResultsIterator() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getResultsIterator() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- getResultsSize() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- getResultsSize() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- getRoot(String) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
- getRoot(Instance) - Static method in class org.apache.accumulo.core.zookeeper.ZooUtil
- getRootTabletLocation() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
- getRootTabletLocation() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
- getRootTabletLocation() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- getRootTabletLocation() - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- getRootTabletLocation() - Method in interface org.apache.accumulo.core.client.Instance
-
Returns the location of the tablet server that is serving the root tablet.
- getRootTabletLocation() - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getRootTabletLocation() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
- getRootTabletLocation(ClientContext) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
- getRootTabletLocation(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- getRootTabletLocation(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- getRootTabletLocation_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- getRootTabletLocation_args(ClientService.getRootTabletLocation_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
-
Performs a deep copy on other.
- getRootTabletLocation_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
- getRootTabletLocation_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- getRootTabletLocation_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- getRootTabletLocation_result(ClientService.getRootTabletLocation_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
-
Performs a deep copy on other.
- getRow() - Method in class org.apache.accumulo.core.data.Key
-
Gets the row ID as a
Text
object. - getRow() - Method in class org.apache.accumulo.core.data.Mutation
-
Gets the row ID for this mutation.
- getRow() - Method in class org.apache.accumulo.core.data.thrift.TKey
- getRow() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getRow() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
- getRow() - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
- getRow(String, Text) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
- getRow(Text) - Method in class org.apache.accumulo.core.data.Key
-
Writes the row ID into the given
Text
. - getRowData() - Method in class org.apache.accumulo.core.data.Key
-
Returns the row ID as a byte sequence.
- getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
- getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
- getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
- getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
- getRowPrefix() - Method in class org.apache.accumulo.core.schema.Section
- getRunning() - Method in class org.apache.accumulo.core.master.thrift.Compacting
- getRuntime() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- getSample(SamplerConfigurationImpl) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
- getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- getSamplerClassName() - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
- getSamplerConfig() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getSamplerConfig() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getSamplerConfiguration() - Method in class org.apache.accumulo.core.client.impl.BaseIteratorEnvironment
- getSamplerConfiguration() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- getSamplerConfiguration() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
- getSamplerConfiguration() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getSamplerConfiguration() - Method in interface org.apache.accumulo.core.client.ScannerBase
- getSamplerConfiguration() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
- getSamplerConfiguration(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
- getSamplerConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Reads the sampling configuration properties for a table.
- getSamplerConfiguration(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- getSaslParams() - Method in class org.apache.accumulo.core.client.impl.ClientContext
-
Retrieve SASL configuration to initiate an RPC connection to a server
- getSaslParams() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
- getSaslProperties() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
- getScanAuthorizations(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Gets the authorizations to set for the scans from the configuration.
- getScanAuthorizations(Class<?>, Configuration) - 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.
- getScanAuthorizations(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Gets the authorizations to set for the scans from the configuration.
- getScanAuthorizations(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Gets the authorizations to set for the scans from the configuration.
- getScanid() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getScanid() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getScanId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- getScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- getScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- getScanner(Connector) - Static method in class org.apache.accumulo.core.replication.ReplicationTable
- getScannerIterator() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
- getScanRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getScans() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getScope() - Method in class org.apache.accumulo.core.trace.Span
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- getSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- getSec() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- getSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- getSecond() - Method in class org.apache.accumulo.core.util.Pair
- getSecret() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- getSecretKeyEncryptionStrategy(String) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
- getSecretKeyEncryptionStrategy(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.security.crypto.CryptoModuleFactory
- getSecs(K) - Method in class org.apache.accumulo.core.util.StopWatch
- getSecurePassword() - Method in class org.apache.accumulo.core.cli.ClientOpts
- getSecureRandom() - Method in class org.apache.accumulo.core.security.crypto.CryptoModuleParameters
-
Gets the initialized secure random object.
- getSecureRandom(String, String) - Static method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModuleUtils
- getSecurityErrorCode() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
- getSecurityErrorCodes() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
- getSerializedFormat() - Method in class org.apache.accumulo.core.data.Mutation
-
Gets the serialization format used to (de)serialize this mutation.
- getSerialVersion() - Method in class org.apache.accumulo.core.bloomfilter.Filter
- getServer() - Method in exception org.apache.accumulo.core.client.impl.AccumuloServerException
- getServer() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- getServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- getServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- getServerProtocols() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getServersShuttingDown() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getServersShuttingDownIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getServersShuttingDownSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getServicedTableId() - Method in class org.apache.accumulo.core.metadata.MetadataServicer
- getServiceName() - Method in class org.apache.accumulo.core.client.impl.DelegationTokenImpl
-
The service name used to identify the
Token
- getServiceName() - Method in class org.apache.accumulo.core.client.mapreduce.impl.DelegationTokenStub
- getServicerAddress() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor.getServicerAddress
- getServicerAddress() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Processor.getServicerAddress
- getServicerAddress(String, TCredentials) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Client
- getServicerAddress(String, TCredentials) - Method in interface org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Iface
- getServicerAddress(String, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient
- getServicerAddress(String, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncIface
- getServicerAddress_args() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- getServicerAddress_args(String, TCredentials) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- getServicerAddress_args(ReplicationCoordinator.getServicerAddress_args) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
-
Performs a deep copy on other.
- getServicerAddress_call(String, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncClient.getServicerAddress_call
- getServicerAddress_result() - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- getServicerAddress_result(String, ReplicationCoordinatorException) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- getServicerAddress_result(ReplicationCoordinator.getServicerAddress_result) - Constructor for class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
-
Performs a deep copy on other.
- getServicerConnection(ClientContext, HostAndPort, long) - Static method in class org.apache.accumulo.core.client.impl.ReplicationClient
-
Attempt a single time to create a ReplicationServicer client to the given host
- getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- getSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- getSessionId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- getShort(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
- getShort(String, short) - 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
- getShort(String, Short) - 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
- getShownLength() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
- getSimulationMode(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.OutputConfigurator
-
Determines whether this feature is enabled.
- getSimulationMode(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.
- getSimulationMode(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Determines whether this feature is enabled.
- getSimulationMode(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Determines whether this feature is enabled.
- getSiteConfiguration() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
- getSiteConfiguration() - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
- getSize() - Method in class org.apache.accumulo.core.data.Key
-
Same as
Key.getLength()
. - getSize() - Method in class org.apache.accumulo.core.data.Value
-
Gets the size of this value.
- getSize() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- getSizeIterator(Connector, String, Text, Text) - Method in class org.apache.accumulo.core.util.Merge
- getSource() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
- getSource(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
- getSources() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getSourcesIterator() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getSourcesSize() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getSourceTableId() - Method in class org.apache.accumulo.core.replication.ReplicationTarget
- getSpan() - Method in class org.apache.accumulo.core.trace.Span
- getSplit() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- getSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- getSplits() - Method in class org.apache.accumulo.core.client.mock.MockTable
-
Deprecated.
- getSplits() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- getSplits(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Deprecated.since 1.5.0; use
TableOperations.listSplits(String)
instead. - getSplits(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Deprecated.
- getSplits(String) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- getSplits(String, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Deprecated.since 1.5.0; use
TableOperations.listSplits(String, int)
instead. - getSplits(String, int) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
-
Deprecated.
- getSplits(JobConf, int) - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Gets the splits of the tables that have been set on the job by reading the metadata table for the specified ranges.
- getSplits(JobContext) - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Gets the splits of the tables that have been set on the job by reading the metadata table for the specified ranges.
- getSsiList() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getSsiList() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getSsio() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getSsio() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getSslParams() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
- getStart() - Method in class org.apache.accumulo.core.data.thrift.TRange
- getStarted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- getStartKey() - Method in class org.apache.accumulo.core.data.Range
-
Gets the start key, or null if the start is negative infinity.
- getStartPos() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockWriter
- getStartPos() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockWrite
- getStartPos() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
-
Get the starting position of the block in the file.
- getStartPos() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
- getStartRow() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
- getStartRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- getStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- getStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- getStartTime() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- getState() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getState() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getState() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- getState() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- getState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getState() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Get counter statistics for this cache.
- getStats() - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
-
Finalize the aggregation and return the result.
- getStats() - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
- getStats() - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
- getStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
- getStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
- getStatus() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
-
If this method throws an exception, then its possible the mutation is still being actively processed.
- getStatus() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- getStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- getStatus() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- getStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
- getStatus(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.Iface
- getStatus(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient
- getStatus(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncIface
- getStatus_args() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- getStatus_args(GCMonitorService.getStatus_args) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
-
Performs a deep copy on other.
- getStatus_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- getStatus_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
- getStatus_result() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- getStatus_result(GCMonitorService.getStatus_result) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
-
Performs a deep copy on other.
- getStatus_result(GCStatus, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- getStdDev() - Method in class org.apache.accumulo.core.util.Stat
- getStop() - Method in class org.apache.accumulo.core.data.thrift.TRange
- getStream() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
- getStream() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
-
It is intended that the caller of this method will close the stream we also only intend that this be called once per BlockRead.
- getString(String) - Method in class org.apache.accumulo.core.client.ClientConfiguration
- getString(String, 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
- getStringArray(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
- getSubstitutor() - 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
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- getSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- getSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- getSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- getSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- getSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- getSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- getSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- getSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- getSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- getSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- getSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- getSuccessSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- getSuccessSize() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- getSum() - Method in class org.apache.accumulo.core.util.Stat
- getSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- getSupportedAlgorithms() - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Compression
- getSymbols() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- getSymbolsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- getSymbolsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- getSymbolTable() - Method in class org.apache.accumulo.core.client.impl.CompressedIterators
- getSyncs() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getSysPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- getSystemConfiguration() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
- getSystemConfiguration() - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
- getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getTable() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getTable() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getTable() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
-
Deprecated.since 1.6.1, use getTableName() instead.
- getTable() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- getTableConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
- getTableConfiguration() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
- getTableConfiguration() - Method in class org.apache.accumulo.core.file.FileOperations.FileAccessOperation
- getTableConfiguration(Connector, String) - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets the configuration specific to a table.
- getTableConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- getTableConfiguration(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- getTableConfiguration(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- getTableConfiguration(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- getTableConfiguration_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- getTableConfiguration_args(ClientService.getTableConfiguration_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
Performs a deep copy on other.
- getTableConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- getTableConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getTableConfiguration_call
- getTableConfiguration_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- getTableConfiguration_result(Map<String, String>, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- getTableConfiguration_result(ClientService.getTableConfiguration_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
Performs a deep copy on other.
- getTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- getTableId() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- getTableId() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getTableId() - Method in class org.apache.accumulo.core.client.mock.MockTable
-
Deprecated.
- getTableId() - Method in exception org.apache.accumulo.core.client.TableDeletedException
- getTableId() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
-
Returns the extent's table id
- getTableId() - Method in class org.apache.accumulo.core.data.impl.TabletIdImpl
- getTableId() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getTableId() - Method in interface org.apache.accumulo.core.data.TabletId
- getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- getTableId(Connector, String) - Method in class org.apache.accumulo.core.client.impl.ReplicationOperationsImpl
- getTableId(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
- getTableId(Key) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReplicationSection
-
Extract the table ID from the colfam
- getTableId(Key) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
-
Extract the table ID from the given key (inefficiently if called repeatedly)
- getTableId(Key) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.StatusSection
-
Extract the table ID from the key (inefficiently if called repeatedly)
- getTableId(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
-
Extract the table ID from the given key
- getTableID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getTableIds(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
- getTableInfo() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
- getTableMap() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getTableMap() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getTableMapSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getTableMapSize() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- getTableName() - Method in class org.apache.accumulo.core.cli.ClientOnDefaultTable
- getTableName() - Method in class org.apache.accumulo.core.cli.ClientOnRequiredTable
- getTableName() - Method in class org.apache.accumulo.core.cli.MapReduceClientOnDefaultTable
- getTableName() - Method in class org.apache.accumulo.core.cli.MapReduceClientOnRequiredTable
- getTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- getTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- getTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- getTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- getTableName() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- getTableName() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getTableName() - Method in exception org.apache.accumulo.core.client.TableNotFoundException
- getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- getTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- getTableName(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
- getTableNames(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Namespaces
- getTables() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
- getTables() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- getTables() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- getTables(MockAccumulo) - Method in class org.apache.accumulo.core.client.mock.MockNamespace
-
Deprecated.
- getTablesIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- getTablesIterator() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- getTablesSize() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- getTablesSize() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- getTableState(Instance, String) - Static method in class org.apache.accumulo.core.client.impl.Tables
- getTableState(Instance, String, boolean) - Static method in class org.apache.accumulo.core.client.impl.Tables
-
Get the current state of the table using the tableid.
- getTablet() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getTablet() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getTablet() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getTablet() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getTablet() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- getTabletLocation(TabletId) - Method in interface org.apache.accumulo.core.client.admin.Locations
-
For any
TabletId
known to this object, the method will return the tablet server location for that tablet. - getTabletLocations(SortedMap<KeyExtent, String>) - Method in class org.apache.accumulo.core.metadata.MetadataServicer
-
Populate the provided data structure with the known tablets for the table being serviced
- getTabletLocator(Class<?>, Configuration) - 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.
- getTabletLocator(Class<?>, Configuration, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Initializes an Accumulo
TabletLocator
based on the configuration. - getTabletLocator(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Deprecated.since 1.6.0
- getTabletLocator(JobConf, String) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Deprecated.since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to discourage its use.
- getTabletLocator(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Deprecated.since 1.6.0
- getTabletLocator(JobContext, String) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Deprecated.since 1.7.0 This method returns a type that is not part of the public API and is not guaranteed to be stable. The method was deprecated to discourage its use.
- getTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- getTabletServer() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
- getTabletServer() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- getTabletServers() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
-
List the currently active tablet servers participating in the accumulo instance
- getTabletServers() - Method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
- getTabletServerStatus() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
- getTabletServerStatus() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
- getTabletServerStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- getTabletServerStatus(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- getTabletServerStatus(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- getTabletServerStatus(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- getTabletServerStatus_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- getTabletServerStatus_args(TabletClientService.getTabletServerStatus_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
-
Performs a deep copy on other.
- getTabletServerStatus_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- getTabletServerStatus_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletServerStatus_call
- getTabletServerStatus_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- getTabletServerStatus_result(TabletServerStatus, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- getTabletServerStatus_result(TabletClientService.getTabletServerStatus_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
-
Performs a deep copy on other.
- getTabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
- getTabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
- getTabletStats(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- getTabletStats(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- getTabletStats(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- getTabletStats(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- getTabletStats_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- getTabletStats_args(TabletClientService.getTabletStats_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
-
Performs a deep copy on other.
- getTabletStats_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- getTabletStats_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.getTabletStats_call
- getTabletStats_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- getTabletStats_result(List<TabletStats>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- getTabletStats_result(TabletClientService.getTabletStats_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
-
Performs a deep copy on other.
- getTarget(Key) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.WorkSection
- getTarget(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.WorkSection
- getTblNspcPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- getTblPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- getTerm(byte[]) - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
- getTerm(Key) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- getTerm(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- getTermEnd() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
- getTermStart() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
- getTermString() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
- getTfino() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.TDiskUsage._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.InitialMultiScan._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.InitialScan._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.IterInfo._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.MapFileInfo._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.MultiScanResult._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.ScanResult._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TCMResult._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TColumn._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TCondition._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TConditionalSession._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TConstraintViolationSummary._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TKey._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TKeyExtent._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TKeyValue._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TMutation._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.TRange._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.data.thrift.UpdateErrors._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.BulkImportStatus._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.Compacting._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.DeadServer._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.RecoveryStatus._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.TableInfo._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.master.thrift.TabletSplit._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.KeyValues._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.replication.thrift.WalEdits._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.security.thrift.TAuthenticationKey._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.security.thrift.TCredentials._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.security.thrift.TDelegationToken._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.security.thrift.TDelegationTokenConfig._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration._Fields
- getThriftFieldId() - Method in enum org.apache.accumulo.core.trace.thrift.TInfo._Fields
- getThriftIdentifier() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- getTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- getTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- getTime() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- getTimeClosed(Key) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
- getTimeClosed(Key, Text) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
- getTimedOutSevers() - Method in exception org.apache.accumulo.core.client.TimedOutException
- getTimeInMillis(String) - Static method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Interprets a string specifying a time duration.
- getTimeInMillis(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Gets a property of type
PropertyType.TIMEDURATION
, interpreting the value properly. - getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
- getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
- getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- getTimeout(TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Returns the setting for how long a scanner will automatically retry when a failure occurs.
- getTimeOut() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
-
Deprecated.
- getTimeOut() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
-
Deprecated.
- getTimeOut() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
-
Deprecated.
- getTimeOut() - Method in class org.apache.accumulo.core.client.IsolatedScanner
-
Deprecated.
- getTimeOut() - Method in class org.apache.accumulo.core.client.mock.MockScanner
-
Deprecated.
- getTimeOut() - Method in interface org.apache.accumulo.core.client.Scanner
-
Deprecated.Since 1.5. See
ScannerBase.getTimeout(java.util.concurrent.TimeUnit)
- getTimestamp() - Method in class org.apache.accumulo.core.data.ColumnUpdate
-
Gets the timestamp for this update.
- getTimestamp() - Method in class org.apache.accumulo.core.data.Condition
-
Gets the timestamp of this condition.
- getTimestamp() - Method in class org.apache.accumulo.core.data.Key
-
Gets the timestamp.
- getTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TKey
- getTimeType() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
-
Retrieve the time type currently configured.
- getTimeZone() - Method in class org.apache.accumulo.core.util.format.DateFormatSupplier
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- getTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- getTinfo() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- getTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- getTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- getTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- getToAuth() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- getToe() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- getToken() - Method in class org.apache.accumulo.core.cli.ClientOpts
- getToken() - Method in class org.apache.accumulo.core.cli.MapReduceClientOpts
- getToken() - Method in class org.apache.accumulo.core.client.impl.Credentials
-
Gets the authentication token.
- getToken() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getToken() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- getToken(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- getToken(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Deprecated.since 1.6.0; Use
AccumuloOutputFormat.getAuthenticationToken(JobConf)
instead. - getToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Deprecated.since 1.6.0; Use
AbstractInputFormat.getAuthenticationToken(JobContext)
instead. - getToken(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Deprecated.since 1.6.0; Use
AccumuloOutputFormat.getAuthenticationToken(JobContext)
instead. - getTokenClass(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- getTokenClass(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Deprecated.since 1.6.0; Use
AccumuloOutputFormat.getAuthenticationToken(JobConf)
instead. - getTokenClass(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Deprecated.since 1.6.0; Use
AbstractInputFormat.getAuthenticationToken(JobContext)
instead. - getTokenClass(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Deprecated.since 1.6.0; Use
AccumuloOutputFormat.getAuthenticationToken(JobContext)
instead. - getTokenClassName() - Method in class org.apache.accumulo.core.cli.ClientOpts
- getTokenClassName() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- getTokenFromFile(Configuration, String, String) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Reads from the token file in distributed cache.
- getTokenLifetime(TimeUnit) - Method in class org.apache.accumulo.core.client.admin.DelegationTokenConfig
-
The current token lifetime.
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- getTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- getTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- getTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- getTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- getTopKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- getTopKey() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- getTopKey() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
- getTopKey() - Method in class org.apache.accumulo.core.iterators.Combiner
- getTopKey() - Method in class org.apache.accumulo.core.iterators.DebugIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.DevNull
- getTopKey() - Method in class org.apache.accumulo.core.iterators.OrIterator
- getTopKey() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
-
Returns top key.
- getTopKey() - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.system.EmptyIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
- getTopKey() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
- getTopKey() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
- getTopValue() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- getTopValue() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- getTopValue() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
- getTopValue() - Method in class org.apache.accumulo.core.iterators.Combiner
- getTopValue() - Method in class org.apache.accumulo.core.iterators.DebugIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.DevNull
- getTopValue() - Method in class org.apache.accumulo.core.iterators.OrIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
- getTopValue() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
-
Returns top value.
- getTopValue() - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.system.EmptyIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
- getTopValue() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
- getTopValue() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
- getTraceId() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- getTransport(HostAndPort, long, ClientContext) - Method in class org.apache.accumulo.core.client.impl.ThriftTransportPool
- getTransport(TTransport) - Method in class org.apache.accumulo.core.rpc.UGIAssumingTransportFactory
- getTrustStorePass() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getTrustStorePath() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getTrustStoreType() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getTs() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- getTServerClient(HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
-
Create a TabletServer Thrift client
- getTServerClient(HostAndPort, ClientContext, long) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
-
Create a TabletServer Thrift client
- getTServerInfo() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getTServerInfoIterator() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getTServerInfoSize() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getTserverLock() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- getTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- getTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- getTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- getTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- getTtl() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- getTTransportParams() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- getType() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
- getType() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getType() - Method in enum org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
-
Deprecated.since 1.7.0 This method returns a type that is not part of the public API and not guaranteed to be stable.
- getType() - Method in class org.apache.accumulo.core.client.impl.ActiveCompactionImpl
- getType() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getType() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- getType() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- getType() - Method in enum org.apache.accumulo.core.conf.Property
-
Gets the type of this property.
- getType() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
- getType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- getType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getUnassignedTablets() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- getUniqueID() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
- getUnknownExceptions() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
- getUnnamedOptionDescriptions() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
- getUpdateCount() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Each time configuration changes, this counter should increase.
- getUpdateCount() - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
- getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- getUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- getUpdates() - Method in class org.apache.accumulo.core.data.Mutation
-
Gets the modifications and deletions in this mutation.
- getUpdates() - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
- getUsage() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
- getUsage() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- getUser() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
- getUser() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
- getUser() - Method in class org.apache.accumulo.core.client.impl.ActiveScanImpl
- getUser() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- getUser() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- getUser() - Method in interface org.apache.accumulo.core.constraints.Constraint.Environment
-
Gets the user within the environment.
- getUser() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- getUserAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
- getUserAuthorizations() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
- getUserAuthorizations(String) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Retrieves the user's authorizations for scanning
- getUserAuthorizations(String) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- getUserAuthorizations(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- getUserAuthorizations(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- getUserAuthorizations(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- getUserAuthorizations(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- getUserAuthorizations_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- getUserAuthorizations_args(ClientService.getUserAuthorizations_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
Performs a deep copy on other.
- getUserAuthorizations_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- getUserAuthorizations_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
- getUserAuthorizations_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- getUserAuthorizations_result(List<ByteBuffer>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- getUserAuthorizations_result(ClientService.getUserAuthorizations_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
Performs a deep copy on other.
- getUUID() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- getUUID() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- getVal() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- getValidExtensions() - Static method in class org.apache.accumulo.core.file.FileOperations
- getValue() - Method in enum org.apache.accumulo.core.client.impl.thrift.ConfigurationType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.client.impl.thrift.TableOperation
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.accumulo.core.data.ColumnUpdate
-
Gets the cell value for this update.
- getValue() - Method in class org.apache.accumulo.core.data.Condition
-
Gets the value of this condition.
- getValue() - Method in enum org.apache.accumulo.core.data.thrift.TCMStatus
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- getValue() - Method in enum org.apache.accumulo.core.master.thrift.BulkImportState
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.master.thrift.FateOperation
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- getValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- getValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- getValue() - Method in enum org.apache.accumulo.core.master.thrift.MasterGoalState
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.master.thrift.MasterState
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.master.thrift.TabletLoadState
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.replication.thrift.RemoteReplicationErrorCode
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorErrorCode
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
- getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionReason
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.CompactionType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ScanState
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.ScanType
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TDurability
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TUnloadTabletGoal
-
Get the integer value of this enum value, as defined in the Thrift IDL.
- getValueFromCredentialProvider(Configuration, String) - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Attempt to extract the password from any configured CredentialsProviders for the given alias.
- getValues() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getValuesIterator() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getValuesSize() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- getVectorSize() - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
- getVersion() - Method in class org.apache.accumulo.core.bloomfilter.Filter
- getViolationCode() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
- getViolationCode() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- getViolationDescription() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
- getViolationDescription() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- getViolationDescription(short) - Method in interface org.apache.accumulo.core.constraints.Constraint
-
Gets a short, one-sentence description of what a given violation code means.
- getViolationDescription(short) - Method in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
- getViolationDescription(short) - Method in class org.apache.accumulo.core.constraints.VisibilityConstraint
- getViolationSummaries() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- getViolationSummaries() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- getViolationSummariesIterator() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- getViolationSummariesIterator() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- getViolationSummariesSize() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- getViolationSummariesSize() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- getVisBlock() - Method in class org.apache.accumulo.core.file.rfile.VisibilityMetric
- getVisBlockPer() - Method in class org.apache.accumulo.core.file.rfile.VisibilityMetric
- getVisibility() - Method in class org.apache.accumulo.core.data.Condition
-
Gets the column visibility of this condition.
- getVisibility() - Method in class org.apache.accumulo.core.file.rfile.VisibilityMetric
- getVisibilityCacheSize(Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Gets the valid visibility count for this job.
- getVisLG() - Method in class org.apache.accumulo.core.file.rfile.VisibilityMetric
- getVisLGPer() - Method in class org.apache.accumulo.core.file.rfile.VisibilityMetric
- getVolume(String, Configuration, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
- getVolumeUris(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
-
Compute the URIs to be used by Accumulo
- getVolumeUris(AccumuloConfiguration, Configuration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
- getWait() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
- getWhy() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- getWrapped() - Method in class org.apache.accumulo.core.rpc.FilterTransport
- getZooKeepers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
- getZooKeepers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
- getZooKeepers() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- getZooKeepers() - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- getZooKeepers() - Method in interface org.apache.accumulo.core.client.Instance
-
Returns a comma-separated list of zookeeper servers the instance is using.
- getZooKeepers() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- getZooKeepers() - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getZooKeepers() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
- getZooKeepers(AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- getZooKeepers(AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- getZooKeepers_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- getZooKeepers_args(ClientService.getZooKeepers_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
-
Performs a deep copy on other.
- getZooKeepers_call(AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.getZooKeepers_call
- getZooKeepers_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- getZooKeepers_result(String) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- getZooKeepers_result(ClientService.getZooKeepers_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
-
Performs a deep copy on other.
- getZooKeepersSessionTimeOut() - Method in interface org.apache.accumulo.core.client.Instance
-
Returns the zookeeper connection timeout.
- getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.client.mock.MockInstance
-
Deprecated.
- getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.client.ZooKeeperInstance
- GLOBAL_CONF_FILENAME - Static variable in class org.apache.accumulo.core.client.ClientConfiguration
- goal - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- GOAL - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
- GOAL_STATE - org.apache.accumulo.core.master.thrift.MasterMonitorInfo._Fields
- goalState - Variable in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- GRANT - org.apache.accumulo.core.security.NamespacePermission
- GRANT - org.apache.accumulo.core.security.SystemPermission
- GRANT - org.apache.accumulo.core.security.TablePermission
- GRANT_INVALID - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- GRANT_INVALID - org.apache.accumulo.core.client.security.SecurityErrorCode
- grantNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
- grantNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
- grantNamespacePermission(String, String, NamespacePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Grant a user a specific permission for a specific namespace
- grantNamespacePermission(String, String, NamespacePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- grantNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- grantNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- grantNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- grantNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- grantNamespacePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- grantNamespacePermission_args(ClientService.grantNamespacePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
Performs a deep copy on other.
- grantNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- grantNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
- grantNamespacePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- grantNamespacePermission_result(ClientService.grantNamespacePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
Performs a deep copy on other.
- grantNamespacePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- grantSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
- grantSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
- grantSystemPermission(String, SystemPermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Grant a user a system permission
- grantSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- grantSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- grantSystemPermission(TInfo, TCredentials, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- grantSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- grantSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- grantSystemPermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- grantSystemPermission_args(ClientService.grantSystemPermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
Performs a deep copy on other.
- grantSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- grantSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantSystemPermission_call
- grantSystemPermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- grantSystemPermission_result(ClientService.grantSystemPermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
-
Performs a deep copy on other.
- grantSystemPermission_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- grantTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
- grantTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
- grantTablePermission(String, String, TablePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Grant a user a specific permission for a specific table
- grantTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- grantTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- grantTablePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- grantTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- grantTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- grantTablePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- grantTablePermission_args(ClientService.grantTablePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
Performs a deep copy on other.
- grantTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- grantTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.grantTablePermission_call
- grantTablePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- grantTablePermission_result(ClientService.grantTablePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
Performs a deep copy on other.
- grantTablePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- GrepIterator - Class in org.apache.accumulo.core.iterators
-
Deprecated.since 1.4, replaced by
GrepIterator
- GrepIterator - Class in org.apache.accumulo.core.iterators.user
-
This iterator provides exact string matching.
- GrepIterator() - Constructor for class org.apache.accumulo.core.iterators.GrepIterator
-
Deprecated.
- GrepIterator() - Constructor for class org.apache.accumulo.core.iterators.user.GrepIterator
- groupByRange() - Method in interface org.apache.accumulo.core.client.admin.Locations
-
For all of the ranges passed to
TableOperations.locate(String, java.util.Collection)
, return a map of the tablets each range overlaps. - groupByTablet() - Method in interface org.apache.accumulo.core.client.admin.Locations
-
For all of the ranges passed to
TableOperations.locate(String, java.util.Collection)
, return a map of the ranges each tablet overlaps. - GSSAPI - org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
- GSSAPI - Static variable in class org.apache.accumulo.core.rpc.ThriftUtil
- GuavaRateLimiter - Class in org.apache.accumulo.core.util.ratelimit
-
Rate limiter from the Guava library.
- GuavaRateLimiter(long) - Constructor for class org.apache.accumulo.core.util.ratelimit.GuavaRateLimiter
-
Constructor
- GZ - org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
H
- HADOOP_CRED_ENTRY_CLASS_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- HADOOP_CRED_ENTRY_GET_CREDENTIAL_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- HADOOP_CRED_PROVIDER_CLASS_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- HADOOP_CRED_PROVIDER_CREATE_CREDENTIAL_ENTRY_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- HADOOP_CRED_PROVIDER_FACTORY_CLASS_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- HADOOP_CRED_PROVIDER_FACTORY_GET_PROVIDERS_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- HADOOP_CRED_PROVIDER_FLUSH_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- HADOOP_CRED_PROVIDER_GET_ALIASES_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- HADOOP_CRED_PROVIDER_GET_CREDENTIAL_ENTRY_METHOD_NAME - Static variable in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
- halt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
- halt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
- halt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- halt(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- halt(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- halt(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- halt_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- halt_args(TabletClientService.halt_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
-
Performs a deep copy on other.
- halt_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- halt_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.halt_call
- halt_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- halt_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- halt_result(TabletClientService.halt_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
-
Performs a deep copy on other.
- handle(Callback[]) - Method in class org.apache.accumulo.core.rpc.SaslClientDigestCallbackHandler
- HAS_TIMESTAMP - org.apache.accumulo.core.data.thrift.TCondition._Fields
- hasColumns(Key) - Method in class org.apache.accumulo.core.util.ColumnFQ
- hash - Variable in class org.apache.accumulo.core.bloomfilter.Filter
-
The hash function used to map a key to several positions in the vector.
- hash(DataOutput, Key) - Method in class org.apache.accumulo.core.client.sample.AbstractHashSampler
-
Subclass must override this method and hash some portion of the key.
- hash(DataOutput, Key) - Method in class org.apache.accumulo.core.client.sample.RowColumnSampler
- hash(DataOutput, Key) - Method in class org.apache.accumulo.core.client.sample.RowSampler
- HASH_COUNT - Static variable in class org.apache.accumulo.core.file.BloomFilterLayer
- hashCode() - Method in class org.apache.accumulo.core.client.admin.CompactionStrategyConfig
- hashCode() - Method in class org.apache.accumulo.core.client.admin.DelegationTokenConfig
- hashCode() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
- hashCode() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
- hashCode() - Method in class org.apache.accumulo.core.client.impl.AuthenticationTokenIdentifier
- hashCode() - Method in class org.apache.accumulo.core.client.impl.Credentials
- hashCode() - Method in class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- hashCode() - Method in class org.apache.accumulo.core.client.impl.TabletLocator.TabletLocation
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- hashCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- hashCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- hashCode() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- hashCode() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
- hashCode() - Method in class org.apache.accumulo.core.client.IteratorSetting
- hashCode() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
- hashCode() - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
- hashCode() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
- hashCode() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
- hashCode() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
- hashCode() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
- hashCode() - Method in class org.apache.accumulo.core.data.ByteSequence
- hashCode() - Method in class org.apache.accumulo.core.data.Column
- hashCode() - Method in class org.apache.accumulo.core.data.ColumnUpdate
- hashCode() - Method in class org.apache.accumulo.core.data.Condition
- hashCode() - Method in class org.apache.accumulo.core.data.ConditionalMutation
- hashCode() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- hashCode() - Method in class org.apache.accumulo.core.data.impl.TabletIdImpl
- hashCode() - Method in class org.apache.accumulo.core.data.Key
- hashCode() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- hashCode() - Method in class org.apache.accumulo.core.data.Mutation
- hashCode() - Method in class org.apache.accumulo.core.data.Range
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TColumn
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TKey
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TMutation
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.TRange
- hashCode() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
- hashCode() - Method in class org.apache.accumulo.core.data.Value
- hashCode() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- hashCode() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
- hashCode() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
- hashCode() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- hashCode() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- hashCode() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- hashCode() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- hashCode() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
- hashCode() - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColFamHashKey
- hashCode() - Method in class org.apache.accumulo.core.iterators.conf.ColumnUtil.ColHashKey
- hashCode() - Method in class org.apache.accumulo.core.iterators.OrIterator.TermSource
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.Compacting
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- hashCode() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- hashCode() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
- hashCode() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- hashCode() - Method in class org.apache.accumulo.core.replication.ReplicationTarget
- hashCode() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
- hashCode() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
- hashCode() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
- hashCode() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
- hashCode() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
- hashCode() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
- hashCode() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
- hashCode() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
- hashCode() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
- hashCode() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
- hashCode() - Method in class org.apache.accumulo.core.rpc.SaslClientDigestCallbackHandler
- hashCode() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
- hashCode() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- hashCode() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
- hashCode() - Method in class org.apache.accumulo.core.security.Authorizations
- hashCode() - Method in class org.apache.accumulo.core.security.ColumnVisibility
- hashCode() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- hashCode() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- hashCode() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
- hashCode() - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
- hashCode() - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
- hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
- hashCode() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
- hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
- hashCode() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
- hashCode() - Method in class org.apache.accumulo.core.util.ColumnFQ
- hashCode() - Method in class org.apache.accumulo.core.util.HostAndPort
- hashCode() - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
- hashCode() - Method in class org.apache.accumulo.core.util.Pair
- hashCode() - Method in class org.apache.accumulo.core.util.ServerServices
- hashCode() - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
- hashCode() - Method in class org.apache.accumulo.core.volume.VolumeImpl
- hashType - Variable in class org.apache.accumulo.core.bloomfilter.Filter
-
Type of hashing function to use.
- hasNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
- hasNamespacePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
- hasNamespacePermission(String, String, NamespacePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Verify the user has a particular namespace permission
- hasNamespacePermission(String, String, NamespacePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- hasNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- hasNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- hasNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- hasNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- hasNamespacePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- hasNamespacePermission_args(ClientService.hasNamespacePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
Performs a deep copy on other.
- hasNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- hasNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
- hasNamespacePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- hasNamespacePermission_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- hasNamespacePermission_result(ClientService.hasNamespacePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
Performs a deep copy on other.
- hasNext() - Method in class org.apache.accumulo.core.client.impl.ScannerIterator
- hasNext() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReaderIterator
- hasNext() - Method in class org.apache.accumulo.core.client.RowIterator
-
Returns true if there is at least one more row to get.
- hasNext() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
- hasNext() - Method in class org.apache.accumulo.core.iterators.Combiner.ValueIterator
- hasNext() - Method in class org.apache.accumulo.core.iterators.IteratorAdapter
- hasNext() - Method in class org.apache.accumulo.core.util.format.DateStringFormatter
-
Deprecated.
- hasNext() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
- hasNext() - Method in class org.apache.accumulo.core.util.format.HexFormatter
- hasNext() - Method in class org.apache.accumulo.core.util.PeekingIterator
- hasPort() - Method in class org.apache.accumulo.core.util.HostAndPort
-
Return true if this instance has a defined port.
- hasPrevious() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
- hasSasl() - Method in class org.apache.accumulo.core.client.ClientConfiguration
-
Show whether SASL has been set on this configuration.
- hasSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
- hasSystemPermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
- hasSystemPermission(String, SystemPermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Verify the user has a particular system permission
- hasSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- hasSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- hasSystemPermission(TInfo, TCredentials, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- hasSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- hasSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- hasSystemPermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- hasSystemPermission_args(ClientService.hasSystemPermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
Performs a deep copy on other.
- hasSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- hasSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasSystemPermission_call
- hasSystemPermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- hasSystemPermission_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- hasSystemPermission_result(ClientService.hasSystemPermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
Performs a deep copy on other.
- hasTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
- hasTablePermission() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
- hasTablePermission(String, String, TablePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Verify the user has a particular table permission
- hasTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- hasTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- hasTablePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- hasTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- hasTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- hasTablePermission_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- hasTablePermission_args(ClientService.hasTablePermission_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
Performs a deep copy on other.
- hasTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- hasTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.hasTablePermission_call
- hasTablePermission_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- hasTablePermission_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- hasTablePermission_result(ClientService.hasTablePermission_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
Performs a deep copy on other.
- hasTimestamp - Variable in class org.apache.accumulo.core.data.thrift.TCondition
- hasTimestamp() - Method in class org.apache.accumulo.core.data.ColumnUpdate
-
Gets whether this update specifies a timestamp.
- hasTop() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- hasTop() - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- hasTop() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
- hasTop() - Method in class org.apache.accumulo.core.iterators.Combiner
- hasTop() - Method in class org.apache.accumulo.core.iterators.DebugIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.DevNull
- hasTop() - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.OrIterator
- hasTop() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
-
Returns true if the iterator has more elements.
- hasTop() - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.system.EmptyIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.system.HeapIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
- hasTop() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.user.RowFilter
- hasTop() - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
- hasTop() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
- hasTop() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
- hasYielded() - Method in class org.apache.accumulo.core.iterators.YieldCallback
-
Called by the client to see if the iterator yielded
- HAVE_LOCK - org.apache.accumulo.core.master.thrift.MasterState
- HDFS_TABLES_DIR - Static variable in class org.apache.accumulo.core.Constants
- HEADER - Static variable in class org.apache.accumulo.core.security.Authorizations
-
A special header string used when serializing instances of this class.
- HeapIterator - Class in org.apache.accumulo.core.iterators.system
-
Constructs a
PriorityQueue
of multiple SortedKeyValueIterators. - HeapIterator() - Constructor for class org.apache.accumulo.core.iterators.system.HeapIterator
- HeapIterator(int) - Constructor for class org.apache.accumulo.core.iterators.system.HeapIterator
- heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlock
- heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.CachedBlockQueue
-
Total size of all elements in this queue.
- heapSize() - Method in interface org.apache.accumulo.core.file.blockfile.cache.HeapSize
- heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
- HeapSize - Interface in org.apache.accumulo.core.file.blockfile.cache
-
Implementations can be asked for an estimate of their size in bytes.
- help - Variable in class org.apache.accumulo.core.cli.Help
- Help - Class in org.apache.accumulo.core.cli
- Help - Class in org.apache.accumulo.core.util
- Help() - Constructor for class org.apache.accumulo.core.cli.Help
- Help() - Constructor for class org.apache.accumulo.core.util.Help
- HexFormatter - Class in org.apache.accumulo.core.util.format
-
A simple formatter that print the row, column family, column qualifier, and value as hex
- HexFormatter() - Constructor for class org.apache.accumulo.core.util.format.HexFormatter
- HexScanInterpreter - Class in org.apache.accumulo.core.util.interpret
-
As simple scan interpreter that converts hex to binary.
- HexScanInterpreter() - Constructor for class org.apache.accumulo.core.util.interpret.HexScanInterpreter
- hit() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache.CacheStats
- HOLD_TIME - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- holdTime - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- HostAndPort - Class in org.apache.accumulo.core.util
-
This class was copied from Guava release 23.0 to replace the older Guava 14 version that had been used in Accumulo.
- HOSTLIST - org.apache.accumulo.core.conf.PropertyType
- HOT_PATH_PROPERTIES - Static variable in enum org.apache.accumulo.core.conf.Property
-
Properties we check the value of within the TabletServer request handling or maintenance processing loops.
- HUMAN_READABLE_FORMAT - Static variable in class org.apache.accumulo.core.util.format.DateFormatSupplier
I
- id - Variable in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- ID - org.apache.accumulo.core.data.thrift.TConditionalMutation._Fields
- ID - Static variable in class org.apache.accumulo.core.metadata.MetadataTable
- ID - Static variable in class org.apache.accumulo.core.metadata.RootTable
- ID - Static variable in class org.apache.accumulo.core.replication.ReplicationTable
- identifier - Variable in class org.apache.accumulo.core.security.thrift.TDelegationToken
- IDENTIFIER - org.apache.accumulo.core.security.thrift.TDelegationToken._Fields
- IDLE - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
-
idle compaction
- IDLE - org.apache.accumulo.core.client.admin.ScanState
- IDLE - org.apache.accumulo.core.tabletserver.thrift.CompactionReason
- IDLE - org.apache.accumulo.core.tabletserver.thrift.ScanState
- IDLE_TIME - org.apache.accumulo.core.tabletserver.thrift.ActiveScan._Fields
- idleTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
- IGNORED - org.apache.accumulo.core.data.thrift.TCMStatus
- IMPORT - org.apache.accumulo.core.client.impl.thrift.TableOperation
- importDirectory(String, String, String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Bulk import all the files in a directory into a table.
- importDirectory(String, String, String, boolean) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- importTable(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Imports a table exported via exportTable and copied via hadoop distcp.
- importTable(String, String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- IN_USE - org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
- includeTransformedKey(Key) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Determines whether or not to include
transformedKey
in the output. - inclusive - Variable in class org.apache.accumulo.core.iterators.system.ColumnFamilySkippingIterator
- increment(KT, long) - Method in class org.apache.accumulo.core.util.MapCounter
- INDEX_CACHE_HITS - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- INDEX_CACHE_REQUEST - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- indexCacheHits - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- indexCacheRequest - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- IndexedDocIterator - Class in org.apache.accumulo.core.iterators.user
-
This iterator facilitates document-partitioned indexing.
- IndexedDocIterator() - Constructor for class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- IndexEntry(boolean) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
- IndexIterator() - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
- IndexIterator(MultiLevelIndex.Reader.Node) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
- indexOf(byte[], int, int) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
- inFileSystem(FileSystem, Configuration) - Method in class org.apache.accumulo.core.file.FileOperations.FileAccessOperation
-
Specify the filesystem which this operation should apply to, along with its configuration.
- inFileSystem(FileSystem, Configuration) - Method in interface org.apache.accumulo.core.file.FileOperations.NeedsFileSystem
-
Specify the
FileSystem
that this operation operates on, along with an alternate configuration. - INFINITE_START_KEY - org.apache.accumulo.core.data.thrift.TRange._Fields
- INFINITE_STOP_KEY - org.apache.accumulo.core.data.thrift.TRange._Fields
- infiniteStartKey - Variable in class org.apache.accumulo.core.data.thrift.TRange
- infiniteStopKey - Variable in class org.apache.accumulo.core.data.thrift.TRange
- INGEST_BYTE_RATE - org.apache.accumulo.core.master.thrift.TableInfo._Fields
- INGEST_RATE - org.apache.accumulo.core.master.thrift.TableInfo._Fields
- INGEST_RATE - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
- ingestByteRate - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
- ingestRate - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
- ingestRate - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- init(Map<String, ArrayList<ByteSequence>>) - Method in interface org.apache.accumulo.core.file.rfile.MetricsGatherer
-
Initialize the gatherer when it is registered with the RFile Reader
- init(Map<String, ArrayList<ByteSequence>>) - Method in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
- init(SamplerConfiguration) - Method in class org.apache.accumulo.core.client.sample.AbstractHashSampler
-
Subclasses with options should override this method and call
super.init(config)
. - init(SamplerConfiguration) - Method in class org.apache.accumulo.core.client.sample.RowColumnSampler
- init(SamplerConfiguration) - Method in interface org.apache.accumulo.core.client.sample.Sampler
-
An implementation of Sampler must have a noarg constructor.
- init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.impl.DelegationTokenImpl
- init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.mapreduce.impl.DelegationTokenStub
- init(AuthenticationToken.Properties) - Method in interface org.apache.accumulo.core.client.security.tokens.AuthenticationToken
- init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
- init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
- init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
- init(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
- init(SortedKeyValueIterator<K, V>, Map<String, String>, IteratorEnvironment) - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
-
Initializes the iterator.
- init(SortedKeyValueIterator<K, V>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SynchronizedIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.file.map.MapFileOperations.RangeIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.AggregatingIterator
-
Deprecated.
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Combiner
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DebugIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.DevNull
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.Filter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.LongCombiner
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SortedMapIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.CountingIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.DeletingIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.EmptyIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.MapFileIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.MultiIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SequenceFileIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.SourceSwitchingIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.system.TimeSettingIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
- init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
- INITIAL - org.apache.accumulo.core.master.thrift.BulkImportState
- INITIAL - org.apache.accumulo.core.master.thrift.MasterState
- initialize(Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Method in class org.apache.accumulo.core.util.format.DateStringFormatter
-
Deprecated.
- initialize(Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
- initialize(Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Method in interface org.apache.accumulo.core.util.format.Formatter
- initialize(Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Method in class org.apache.accumulo.core.util.format.HexFormatter
- initialize(Iterator<E>) - Method in class org.apache.accumulo.core.util.PeekingIterator
-
Initializes this iterator, to be used with
PeekingIterator()
. - initialize(InputSplit, JobConf) - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
-
Initialize a scanner over the given input split using this task attempt configuration.
- initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat.AbstractRecordReader
- initializeCipher(CryptoModuleParameters) - Method in interface org.apache.accumulo.core.security.crypto.CryptoModule
-
Generates a
Cipher
object based on the parameters in the givenCryptoModuleParameters
object and places it into theCryptoModuleParameters.getCipher()
property. - initializeCipher(CryptoModuleParameters) - Method in class org.apache.accumulo.core.security.crypto.DefaultCryptoModule
- InitialMultiScan - Class in org.apache.accumulo.core.data.thrift
- InitialMultiScan() - Constructor for class org.apache.accumulo.core.data.thrift.InitialMultiScan
- InitialMultiScan(long, MultiScanResult) - Constructor for class org.apache.accumulo.core.data.thrift.InitialMultiScan
- InitialMultiScan(InitialMultiScan) - Constructor for class org.apache.accumulo.core.data.thrift.InitialMultiScan
-
Performs a deep copy on other.
- InitialMultiScan._Fields - Enum in org.apache.accumulo.core.data.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- InitialScan - Class in org.apache.accumulo.core.data.thrift
- InitialScan() - Constructor for class org.apache.accumulo.core.data.thrift.InitialScan
- InitialScan(long, ScanResult) - Constructor for class org.apache.accumulo.core.data.thrift.InitialScan
- InitialScan(InitialScan) - Constructor for class org.apache.accumulo.core.data.thrift.InitialScan
-
Performs a deep copy on other.
- InitialScan._Fields - Enum in org.apache.accumulo.core.data.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- initiateFlush() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
- initiateFlush() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.initiateFlush
- initiateFlush(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Client
- initiateFlush(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.Iface
- initiateFlush(TInfo, TCredentials, String, AsyncMethodCallback) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient
- initiateFlush(TInfo, TCredentials, String, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.master.thrift.MasterClientService.AsyncIface
- initiateFlush_args() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- initiateFlush_args(MasterClientService.initiateFlush_args) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
-
Performs a deep copy on other.
- initiateFlush_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
- initiateFlush_call(TInfo, TCredentials, String, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncClient.initiateFlush_call
- initiateFlush_result() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- initiateFlush_result(long, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
- initiateFlush_result(MasterClientService.initiateFlush_result) - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
-
Performs a deep copy on other.
- INLINE - org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.TokenSource
- INPUT_FILES - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
- InputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.impl
- InputConfigurator - Class in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- InputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
- InputConfigurator() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator
-
Deprecated.
- InputConfigurator.Features - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
Configuration keys for various features.
- InputConfigurator.Features - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- InputConfigurator.ScanOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.impl
-
Configuration keys for
Scanner
. - InputConfigurator.ScanOpts - Enum in org.apache.accumulo.core.client.mapreduce.lib.util
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- inputFiles - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- InputFormatBase<K,V> - Class in org.apache.accumulo.core.client.mapred
-
This abstract
InputFormat
class allows MapReduce jobs to use Accumulo as the source of K,V pairs. - InputFormatBase<K,V> - Class in org.apache.accumulo.core.client.mapreduce
-
This abstract
InputFormat
class allows MapReduce jobs to use Accumulo as the source of K,V pairs. - InputFormatBase() - Constructor for class org.apache.accumulo.core.client.mapred.InputFormatBase
- InputFormatBase() - Constructor for class org.apache.accumulo.core.client.mapreduce.InputFormatBase
- InputFormatBase.RangeInputSplit - Class in org.apache.accumulo.core.client.mapred
-
Deprecated.since 1.5.2; Use
RangeInputSplit
instead. - InputFormatBase.RangeInputSplit - Class in org.apache.accumulo.core.client.mapreduce
-
Deprecated.since 1.5.2; Use
RangeInputSplit
instead. - InputFormatBase.RecordReaderBase<K,V> - Class in org.apache.accumulo.core.client.mapred
- InputFormatBase.RecordReaderBase<K,V> - Class in org.apache.accumulo.core.client.mapreduce
- InputTableConfig - Class in org.apache.accumulo.core.client.mapreduce
-
This class to holds a batch scan configuration for a table.
- InputTableConfig() - Constructor for class org.apache.accumulo.core.client.mapreduce.InputTableConfig
- InputTableConfig(DataInput) - Constructor for class org.apache.accumulo.core.client.mapreduce.InputTableConfig
-
Creates a batch scan config object out of a previously serialized batch scan config object.
- inst - Variable in class org.apache.accumulo.core.client.impl.ClientContext
- instance - Variable in class org.apache.accumulo.core.cli.ClientOpts
- Instance - Interface in org.apache.accumulo.core.client
-
This class represents the information a client needs to know to connect to an instance of accumulo.
- INSTANCE - Static variable in class org.apache.accumulo.core.util.ratelimit.NullRateLimiter
- INSTANCE_DFS_DIR - org.apache.accumulo.core.conf.Property
-
Deprecated.
- INSTANCE_DFS_URI - org.apache.accumulo.core.conf.Property
-
Deprecated.
- INSTANCE_ID - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- INSTANCE_ID - org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
- INSTANCE_ID - org.apache.accumulo.core.security.thrift.TCredentials._Fields
- INSTANCE_NAME - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- INSTANCE_PREFIX - org.apache.accumulo.core.conf.Property
- INSTANCE_RPC_SASL_ALLOWED_HOST_IMPERSONATION - org.apache.accumulo.core.conf.Property
- INSTANCE_RPC_SASL_ALLOWED_USER_IMPERSONATION - org.apache.accumulo.core.conf.Property
- INSTANCE_RPC_SASL_ENABLED - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- INSTANCE_RPC_SASL_ENABLED - org.apache.accumulo.core.conf.Property
- INSTANCE_RPC_SASL_PROXYUSERS - org.apache.accumulo.core.conf.Property
-
Deprecated.
- INSTANCE_RPC_SSL_CLIENT_AUTH - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- INSTANCE_RPC_SSL_CLIENT_AUTH - org.apache.accumulo.core.conf.Property
- INSTANCE_RPC_SSL_ENABLED - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- INSTANCE_RPC_SSL_ENABLED - org.apache.accumulo.core.conf.Property
- INSTANCE_SECRET - org.apache.accumulo.core.conf.Property
- INSTANCE_SECURITY_AUTHENTICATOR - org.apache.accumulo.core.conf.Property
- INSTANCE_SECURITY_AUTHORIZOR - org.apache.accumulo.core.conf.Property
- INSTANCE_SECURITY_PERMISSION_HANDLER - org.apache.accumulo.core.conf.Property
- INSTANCE_VOLUMES - org.apache.accumulo.core.conf.Property
- INSTANCE_VOLUMES_REPLACEMENTS - org.apache.accumulo.core.conf.Property
- INSTANCE_ZK_HOST - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- INSTANCE_ZK_HOST - org.apache.accumulo.core.conf.Property
- INSTANCE_ZK_TIMEOUT - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- INSTANCE_ZK_TIMEOUT - org.apache.accumulo.core.conf.Property
- instanceId - Variable in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- instanceId - Variable in class org.apache.accumulo.core.security.thrift.TCredentials
- instanceOperations() - Method in class org.apache.accumulo.core.client.Connector
-
Retrieves an InstanceOperations object to modify instance configuration.
- instanceOperations() - Method in class org.apache.accumulo.core.client.impl.ConnectorImpl
- instanceOperations() - Method in class org.apache.accumulo.core.client.mock.MockConnector
-
Deprecated.
- InstanceOperations - Interface in org.apache.accumulo.core.client.admin
- InstanceOperationsImpl - Class in org.apache.accumulo.core.client.impl
-
Provides a class for administering the accumulo instance
- InstanceOperationsImpl(ClientContext) - Constructor for class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
- instantiateClassProperty(Property, Class<T>, T) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Creates a new instance of a class specified in a configuration property.
- INSUFFICIENT_PROPERTIES - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- INSUFFICIENT_PROPERTIES - org.apache.accumulo.core.client.security.SecurityErrorCode
- INTEGER - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for an Integer
- IntegerLexicoder - Class in org.apache.accumulo.core.client.lexicoder
-
A lexicoder for signed integers.
- IntegerLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.IntegerLexicoder
- INTERFACE_MATCH - org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args._Fields
- INTERFACE_MATCH - org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args._Fields
- INTERFACE_MATCH - org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args._Fields
- interfaceMatch - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- interfaceMatch - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- interfaceMatch - Variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- interpolate(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
- interpolate(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
- interpolatedConfiguration() - 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
- interpolateHelper(String, List) - 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
- interpretBeginRow(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
- interpretBeginRow(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
- interpretBeginRow(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
- interpretColumnFamily(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
- interpretColumnFamily(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
- interpretColumnFamily(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
- interpretColumnQualifier(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
- interpretColumnQualifier(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
- interpretColumnQualifier(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
- interpretEndRow(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
- interpretEndRow(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
- interpretEndRow(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
- interpretRow(Text) - Method in class org.apache.accumulo.core.util.format.HexFormatter
- interpretRow(Text) - Method in class org.apache.accumulo.core.util.interpret.DefaultScanInterpreter
- interpretRow(Text) - Method in interface org.apache.accumulo.core.util.interpret.ScanInterpreter
- InterruptibleIterator - Interface in org.apache.accumulo.core.iterators.system
- IntersectingIterator - Class in org.apache.accumulo.core.iterators
-
Deprecated.since 1.4, replaced by
IntersectingIterator
- IntersectingIterator - Class in org.apache.accumulo.core.iterators.user
-
This iterator facilitates document-partitioned indexing.
- IntersectingIterator() - Constructor for class org.apache.accumulo.core.iterators.IntersectingIterator
-
Deprecated.
- IntersectingIterator() - Constructor for class org.apache.accumulo.core.iterators.user.IntersectingIterator
- IntersectingIterator.TermSource - Class in org.apache.accumulo.core.iterators.user
- inUse - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- INVALID_INSTANCEID - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- INVALID_INSTANCEID - org.apache.accumulo.core.client.security.SecurityErrorCode
- INVALID_NAME - org.apache.accumulo.core.client.impl.thrift.TableOperationExceptionType
- INVALID_TOKEN - org.apache.accumulo.core.client.impl.thrift.SecurityErrorCode
- INVALID_TOKEN - org.apache.accumulo.core.client.security.SecurityErrorCode
- invalidateCache() - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
- invalidateCache() - Method in class org.apache.accumulo.core.client.impl.SyncingTabletLocator
- invalidateCache() - Method in class org.apache.accumulo.core.client.impl.TabletLocator
-
Invalidate entire cache
- invalidateCache() - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- invalidateCache() - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
-
Deprecated.
- invalidateCache() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Invalidates the
ZooCache
used for storage and quick retrieval of properties for this configuration. - invalidateCache(String) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletServerLockChecker
- invalidateCache(String) - Method in class org.apache.accumulo.core.client.impl.ZookeeperLockChecker
- invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
- invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.impl.SyncingTabletLocator
- invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
- invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
-
Deprecated.
- invalidateCache(Instance, String) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
- invalidateCache(Instance, String) - Method in class org.apache.accumulo.core.client.impl.SyncingTabletLocator
- invalidateCache(Instance, String) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
-
Invalidate all metadata entries that point to server
- invalidateCache(Instance, String) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- invalidateCache(Instance, String) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
-
Deprecated.
- invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
- invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.SyncingTabletLocator
- invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
- invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
-
Deprecated.
- invalidateConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
- invalidateConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
- invalidateConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- invalidateConditionalUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- invalidateConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- invalidateConditionalUpdate(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- invalidateConditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- invalidateConditionalUpdate_args(TabletClientService.invalidateConditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
-
Performs a deep copy on other.
- invalidateConditionalUpdate_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
- invalidateConditionalUpdate_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.invalidateConditionalUpdate_call
- invalidateConditionalUpdate_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
- invalidateConditionalUpdate_result(TabletClientService.invalidateConditionalUpdate_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
-
Performs a deep copy on other.
- invalidMessage(T) - Method in class org.apache.accumulo.core.util.Validator
-
Formulates an exception message for invalid values.
- INVISIBLE_VISIBILITY - org.apache.accumulo.core.client.ConditionalWriter.Status
-
A condition contained a column visibility that could never be seen
- invoke(Object, Method, Object[]) - Method in class org.apache.accumulo.core.trace.wrappers.RpcClientInvocationHandler
- invoke(Object, Method, Object[]) - Method in class org.apache.accumulo.core.trace.wrappers.RpcServerInvocationHandler
- IS_CONFIGURED - org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.ConnectorInfo
- IS_CONFIGURED - org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase.ConnectorInfo
-
Deprecated.
- isActive() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
- isActive() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
- isActive(TInfo, long) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- isActive(TInfo, long) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- isActive(TInfo, long, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- isActive(TInfo, long, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- isActive_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- isActive_args(ClientService.isActive_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
Performs a deep copy on other.
- isActive_args(TInfo, long) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- isActive_call(TInfo, long, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.isActive_call
- isActive_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- isActive_result(boolean) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- isActive_result(ClientService.isActive_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
-
Performs a deep copy on other.
- isAdvertiseViaMulticastDNS() - Method in class org.apache.accumulo.core.util.AsyncSocketAppender
- isAutoClean() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- isBackedByArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
- isBackedByArray() - Method in class org.apache.accumulo.core.data.ByteSequence
-
Determines whether this sequence is backed by a byte array.
- isBatchScan(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Determines whether a configuration has the BatchScanner feature enabled.
- isBatchScan(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Determines whether a configuration has the
BatchScanner
feature enabled. - isBatchScan(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Determines whether a configuration has the
BatchScanner
feature enabled. - isClassProperty(String) - Static method in enum org.apache.accumulo.core.conf.Property
-
Checks if this property is expected to have a Java class as a value.
- isClientAuth() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- isClosed() - Method in class org.apache.accumulo.core.client.impl.MultiTableBatchWriterImpl
- isClosed() - Method in class org.apache.accumulo.core.client.mock.MockMultiTableBatchWriter
-
Deprecated.
- isClosed() - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
-
Returns true if this batch writer has been closed.
- isConnectorInfoSet(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase
-
Determines if the connector info has already been set for this instance.
- isConnectorInfoSet(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- isConnectorInfoSet(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
-
Determines if the connector has been configured.
- isConnectorInfoSet(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
-
Determines if the connector has been configured.
- isConnectorInfoSet(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
-
Determines if the connector has been configured.
- isConnectorInfoSet(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
-
Determines if the connector has been configured.
- isCurrent() - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
- isCurrent(ZooCache) - Method in class org.apache.accumulo.core.client.impl.TableMap
- isDefaultLocalityGroup - Variable in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
- isDeleted() - Method in class org.apache.accumulo.core.data.ColumnUpdate
-
Gets the delete marker for this update.
- isDeleted() - Method in class org.apache.accumulo.core.data.Key
-
Determines if this key is deleted (i.e., has a delete marker = true).
- isDelimiterParsingDisabled() - 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
- isDeprecated() - Method in enum org.apache.accumulo.core.conf.Property
-
Checks if this property is deprecated.
- isDestroyed() - Method in class org.apache.accumulo.core.client.mapreduce.impl.DelegationTokenStub
- isDestroyed() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
- isDestroyed() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
- isDestroyed() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
- isDestroyed() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
- isDetailEvents() - 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
- isDoTimestamps() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
- isEmpty() - 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
- isEmpty() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
- isEmpty() - Method in class org.apache.accumulo.core.constraints.Violations
-
Checks if this object is empty, i.e., that no violations have been added.
- isEmpty() - Method in class org.apache.accumulo.core.iterators.conf.ColumnSet
- isEmpty() - Method in class org.apache.accumulo.core.iterators.conf.ColumnToClassMapping
- isEmpty() - Method in class org.apache.accumulo.core.security.Authorizations
-
Checks if this collection of authorizations is empty.
- isEnabled(KeyExtent, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.replication.ReplicationConfigurationUtil
-
Determines if the replication is enabled for the given
KeyExtent
- isEndKeyInclusive() - Method in class org.apache.accumulo.core.data.Range
-
Gets whether the end key of this range is inclusive.
- isExperimental() - Method in enum org.apache.accumulo.core.conf.Property
-
Checks if this property is experimental.
- isFixedZooPropertyKey(Property) - Static method in enum org.apache.accumulo.core.conf.Property
-
Checks if the given property may be changed via Zookeeper, but not recognized until the restart of some relevant daemon.
- isFlush() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
-
Determines if memory is flushed in the source table before cloning.
- isFlush() - Method in class org.apache.accumulo.core.client.impl.CloneConfigurationImpl
- isForce() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
- isFullMajorCompaction() - Method in class org.apache.accumulo.core.client.impl.BaseIteratorEnvironment
- isFullMajorCompaction() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
- isHadoopCredentialProviderAvailable() - Static method in class org.apache.accumulo.core.conf.CredentialProviderFactoryShim
-
Determine if we can load the necessary CredentialProvider classes.
- isHasTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TCondition
- isIndexable() - Method in interface org.apache.accumulo.core.file.blockfile.ABlockReader
-
An indexable block supports seeking, getting a position, and associating an arbitrary index with the block
- isIndexable() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.BlockRead
- isIndexable() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
- isInfiniteStartKey() - Method in class org.apache.accumulo.core.data.Range
-
Gets whether the start key is negative infinity.
- isInfiniteStartKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
- isInfiniteStopKey() - Method in class org.apache.accumulo.core.data.Range
-
Gets whether the end key is positive infinity.
- isInfiniteStopKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
- isIsolated() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- isIsolated(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Determines whether a configuration has isolation enabled.
- isIsolated(Class<?>, Configuration) - 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.
- isIsolated(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Determines whether a configuration has isolation enabled.
- isIsolated(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Determines whether a configuration has isolation enabled.
- isIsolatedScan() - Method in class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
- isIsolatedScan() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- isKeepOffline() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
-
The new table is normally brought online after the cloning process.
- isKeepOffline() - Method in class org.apache.accumulo.core.client.impl.CloneConfigurationImpl
- isKeyStoreSet() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- isLastInclusive() - Method in class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroupSeekCache
- isLocalityGroupProperty(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
- isLockHeld(String, String) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletServerLockChecker
- isLockHeld(String, String) - Method in class org.apache.accumulo.core.client.impl.ZookeeperLockChecker
- isMeta() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- isMeta() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- isMockInstance() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
-
Deprecated.since 1.8.0; use MiniAccumuloCluster or a standard mock framework
- isMockInstance(Instance) - Static method in class org.apache.accumulo.core.util.DeprecationUtil
- isMockInstanceSet(RangeInputSplit) - Static method in class org.apache.accumulo.core.util.DeprecationUtil
- isMore() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- isMore() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
- isOffline() - Method in class org.apache.accumulo.core.client.mapreduce.impl.BatchInputSplit
- isOffline() - Method in class org.apache.accumulo.core.client.mapreduce.RangeInputSplit
- isOfflineScan() - Method in class org.apache.accumulo.core.client.mapreduce.InputTableConfig
-
Determines whether a configuration has the offline table scan feature enabled.
- isOfflineScan(Class<?>, Configuration) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator
-
Determines whether a configuration has the offline table scan feature enabled.
- isOfflineScan(Class<?>, Configuration) - 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.
- isOfflineScan(JobConf) - Static method in class org.apache.accumulo.core.client.mapred.InputFormatBase
-
Determines whether a configuration has the offline table scan feature enabled.
- isOfflineScan(JobContext) - Static method in class org.apache.accumulo.core.client.mapreduce.InputFormatBase
-
Determines whether a configuration has the offline table scan feature enabled.
- isolated - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- ISOLATED - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args._Fields
- IsolatedScanner - Class in org.apache.accumulo.core.client
-
A scanner that presents a row isolated view of an accumulo table.
- IsolatedScanner(Scanner) - Constructor for class org.apache.accumulo.core.client.IsolatedScanner
- IsolatedScanner(Scanner, IsolatedScanner.RowBufferFactory) - Constructor for class org.apache.accumulo.core.client.IsolatedScanner
- IsolatedScanner.MemoryRowBuffer - Class in org.apache.accumulo.core.client
- IsolatedScanner.MemoryRowBufferFactory - Class in org.apache.accumulo.core.client
- IsolatedScanner.RowBuffer - Interface in org.apache.accumulo.core.client
- IsolatedScanner.RowBufferFactory - Interface in org.apache.accumulo.core.client
- IsolationException - Exception in org.apache.accumulo.core.client.impl
- IsolationException() - Constructor for exception org.apache.accumulo.core.client.impl.IsolationException
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticate
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.authenticateUser
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.bulkImportFiles
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeAuthorizations
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkClass
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.checkTableClass
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.createLocalUser
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.dropLocalUser
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getConfiguration
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getDiskUsage
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getInstanceId
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getTableConfiguration
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.getZooKeepers
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantSystemPermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.grantTablePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasSystemPermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.hasTablePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.isActive
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.ping
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.revokeTablePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticate
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.authenticateUser
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.bulkImportFiles
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeAuthorizations
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.changeLocalUserPassword
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkClass
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkNamespaceClass
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.checkTableClass
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.createLocalUser
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.dropLocalUser
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getConfiguration
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getDiskUsage
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getInstanceId
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getNamespaceConfiguration
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getRootTabletLocation
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getTableConfiguration
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getUserAuthorizations
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.getZooKeepers
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantNamespacePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantSystemPermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.grantTablePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasNamespacePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasSystemPermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.hasTablePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.isActive
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.ping
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeNamespacePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeSystemPermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.revokeTablePermission
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.fails
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.success
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.AsyncProcessor.throwsError
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.fails
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.success
- isOneway() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.Processor.throwsError
- isOneway() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
- isOneway() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.beginFateOperation
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.executeFateOperation
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.finishFateOperation
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.AsyncProcessor.waitForFateOperation
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.beginFateOperation
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.executeFateOperation
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.finishFateOperation
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.FateService.Processor.waitForFateOperation
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.drainReplicationTable
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getActiveTservers
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getDelegationToken
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.getMasterStats
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.initiateFlush
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeNamespaceProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeSystemProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.removeTableProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportSplitExtent
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.reportTabletStatus
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setMasterGoalState
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setNamespaceProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setSystemProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.setTableProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdown
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.shutdownTabletServer
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForBalance
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.AsyncProcessor.waitForFlush
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.drainReplicationTable
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getActiveTservers
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getDelegationToken
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.getMasterStats
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.initiateFlush
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeNamespaceProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeSystemProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.removeTableProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportSplitExtent
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.reportTabletStatus
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setMasterGoalState
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setNamespaceProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setSystemProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.setTableProperty
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdown
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.shutdownTabletServer
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForBalance
- isOneway() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.Processor.waitForFlush
- isOneway() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.AsyncProcessor.getServicerAddress
- isOneway() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.Processor.getServicerAddress
- isOneway() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateKeyValues
- isOneway() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.AsyncProcessor.replicateLog
- isOneway() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateKeyValues
- isOneway() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.Processor.replicateLog
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.applyUpdates
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.bulkImport
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.chop
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeConditionalUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeMultiScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.closeUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.compact
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.conditionalUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueMultiScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.continueScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.fastHalt
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flush
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.flushTablet
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveCompactions
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveLogs
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getActiveScans
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getHistoricalStats
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletServerStatus
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.getTabletStats
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.halt
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.invalidateConditionalUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.removeLogs
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.splitTablet
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startConditionalUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startMultiScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.startUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.unloadTablet
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.update
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.applyUpdates
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.bulkImport
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.chop
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeConditionalUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeMultiScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.closeUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.compact
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.conditionalUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueMultiScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.continueScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.fastHalt
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flush
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.flushTablet
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveCompactions
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveLogs
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getActiveScans
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getHistoricalStats
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletServerStatus
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.getTabletStats
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.halt
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.invalidateConditionalUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.removeLogs
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.splitTablet
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startConditionalUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startMultiScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startScan
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.startUpdate
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.unloadTablet
- isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.update
- isOnline(Connector) - Static method in class org.apache.accumulo.core.replication.ReplicationTable
- isOpen() - Method in class org.apache.accumulo.core.rpc.FilterTransport
- isPartNextKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
- isPreviousExtent(KeyExtent) - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- isPreviousExtent(KeyExtent) - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- isRangeInclusive() - Method in class org.apache.accumulo.core.file.FileOperations.OpenScanReaderOperation
- isRootTablet() - Method in class org.apache.accumulo.core.data.impl.KeyExtent
- isRootTablet() - Method in class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- isRunning() - Method in class org.apache.accumulo.core.util.OpTimer
-
Returns timer running state
- isSamplingEnabled() - Method in class org.apache.accumulo.core.client.impl.BaseIteratorEnvironment
- isSamplingEnabled() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
-
There are at least two conditions under which sampling will be enabled for an environment.
- isSasl() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
- isSeekToBeginning() - Method in class org.apache.accumulo.core.file.FileOperations.OpenReaderOperation
- isSensitive() - Method in enum org.apache.accumulo.core.conf.Property
-
Checks if this property is sensitive.
- isSensitive(String) - Static method in enum org.apache.accumulo.core.conf.Property
-
Checks if a property with the given key is sensitive.
- isSet(ClientService.authenticate_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.authenticate_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.authenticateUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.authenticateUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.bulkImportFiles_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.bulkImportFiles_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.changeAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.changeAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.changeLocalUserPassword_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.changeLocalUserPassword_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.checkClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.checkClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.checkNamespaceClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.checkNamespaceClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.checkTableClass_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.checkTableClass_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.createLocalUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.createLocalUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.dropLocalUser_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.dropLocalUser_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getDiskUsage_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getDiskUsage_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getInstanceId_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getInstanceId_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getNamespaceConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getNamespaceConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getRootTabletLocation_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getRootTabletLocation_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getTableConfiguration_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getTableConfiguration_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getUserAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getUserAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getZooKeepers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.getZooKeepers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.grantNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.grantNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.grantSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.grantSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.grantTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.grantTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.hasNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.hasNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.hasSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.hasSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.hasTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.hasTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.isActive_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.isActive_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.listLocalUsers_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.listLocalUsers_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.ping_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.ping_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.revokeNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.revokeNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.revokeSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.revokeSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.revokeTablePermission_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ClientService.revokeTablePermission_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TDiskUsage._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftSecurityException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftTableOperationException._Fields) - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftTest.fails_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftTest.fails_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftTest.success_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftTest.success_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftTest.throwsError_args._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ThriftTest.throwsError_result._Fields) - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(InitialMultiScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(InitialScan._Fields) - Method in class org.apache.accumulo.core.data.thrift.InitialScan
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(IterInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.IterInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MapFileInfo._Fields) - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MultiScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ScanResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.ScanResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TCMResult._Fields) - Method in class org.apache.accumulo.core.data.thrift.TCMResult
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TColumn._Fields) - Method in class org.apache.accumulo.core.data.thrift.TColumn
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TCondition._Fields) - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TConditionalMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TConditionalSession._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TConstraintViolationSummary._Fields) - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TKey._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKey
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TKeyExtent._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TKeyValue._Fields) - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TMutation._Fields) - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TRange._Fields) - Method in class org.apache.accumulo.core.data.thrift.TRange
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(UpdateErrors._Fields) - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(GcCycleStats._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(GCMonitorService.getStatus_args._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(GCMonitorService.getStatus_result._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(GCStatus._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(BulkImportStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(Compacting._Fields) - Method in class org.apache.accumulo.core.master.thrift.Compacting
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(DeadServer._Fields) - Method in class org.apache.accumulo.core.master.thrift.DeadServer
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(FateService.beginFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(FateService.beginFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(FateService.executeFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(FateService.executeFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(FateService.finishFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(FateService.finishFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(FateService.waitForFateOperation_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(FateService.waitForFateOperation_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.drainReplicationTable_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.drainReplicationTable_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.getActiveTservers_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.getActiveTservers_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.getDelegationToken_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.getDelegationToken_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.getMasterStats_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.getMasterStats_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.initiateFlush_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.initiateFlush_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.removeNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.removeNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.removeSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.removeSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.removeTableProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.removeTableProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.reportSplitExtent_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.reportTabletStatus_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.setMasterGoalState_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.setMasterGoalState_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.setNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.setNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.setSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.setSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.setTableProperty_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.setTableProperty_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.shutdown_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.shutdown_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.shutdownTabletServer_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.shutdownTabletServer_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.waitForBalance_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.waitForBalance_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.waitForFlush_args._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterClientService.waitForFlush_result._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(MasterMonitorInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(RecoveryException._Fields) - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(RecoveryStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TableInfo._Fields) - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletServerStatus._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletSplit._Fields) - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(KeyValues._Fields) - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(RemoteReplicationException._Fields) - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ReplicationCoordinator.getServicerAddress_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ReplicationCoordinator.getServicerAddress_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ReplicationCoordinatorException._Fields) - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ReplicationServicer.replicateKeyValues_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ReplicationServicer.replicateKeyValues_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ReplicationServicer.replicateLog_args._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ReplicationServicer.replicateLog_result._Fields) - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(WalEdits._Fields) - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TAuthenticationKey._Fields) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TAuthenticationTokenIdentifier._Fields) - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TCredentials._Fields) - Method in class org.apache.accumulo.core.security.thrift.TCredentials
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TDelegationToken._Fields) - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TDelegationTokenConfig._Fields) - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ActionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ActiveCompaction._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ActiveScan._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(ConstraintViolationException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(IteratorConfig._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(NoSuchScanIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(NotServingTabletException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.applyUpdates_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.bulkImport_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.bulkImport_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.chop_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.closeConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.closeMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.closeMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.closeScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.closeUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.closeUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.compact_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.conditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.conditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.continueMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.continueMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.continueScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.continueScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.fastHalt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.flush_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.flushTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getActiveLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getActiveLogs_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getActiveScans_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getActiveScans_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getHistoricalStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getHistoricalStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getTabletServerStatus_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getTabletServerStatus_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getTabletStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.getTabletStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.halt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.halt_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.invalidateConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.invalidateConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.loadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.removeLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.splitTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.splitTablet_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.startConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.startConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.startMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.startMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.startScan_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.startScan_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.startUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.startUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.unloadTablet_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.update_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletClientService.update_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TabletStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TIteratorSetting._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TooManyFilesException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TSampleNotPresentException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TSamplerConfiguration._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSet(TInfo._Fields) - Method in class org.apache.accumulo.core.trace.thrift.TInfo
-
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
- isSetAfterPart(Key, PartialKey) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
-
Indicates whether or not any part of
key
excludingpart
is set. - isSetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field age is set (has been assigned a value) and false otherwise
- isSetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field age is set (has been assigned a value) and false otherwise
- isSetArguments() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Returns true if field arguments is set (has been assigned a value) and false otherwise
- isSetAuthorizationFailures() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
-
Returns true if field authorizationFailures is set (has been assigned a value) and false otherwise
- isSetAuthorizations() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
Returns true if field authorizations is set (has been assigned a value) and false otherwise
- isSetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field authorizations is set (has been assigned a value) and false otherwise
- isSetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
Returns true if field authorizations is set (has been assigned a value) and false otherwise
- isSetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field authorizations is set (has been assigned a value) and false otherwise
- isSetAuthorizations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field authorizations is set (has been assigned a value) and false otherwise
- isSetAutoClean() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Returns true if field autoClean is set (has been assigned a value) and false otherwise
- isSetBadTServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field badTServers is set (has been assigned a value) and false otherwise
- isSetBatch() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field batch is set (has been assigned a value) and false otherwise
- isSetBatchSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field batchSize is set (has been assigned a value) and false otherwise
- isSetBatchTimeOut() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field batchTimeOut is set (has been assigned a value) and false otherwise
- isSetBatchTimeOut() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field batchTimeOut is set (has been assigned a value) and false otherwise
- isSetBulkImports() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field bulkImports is set (has been assigned a value) and false otherwise
- isSetBulkImports() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field bulkImports is set (has been assigned a value) and false otherwise
- isSetCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
Returns true if field candidates is set (has been assigned a value) and false otherwise
- isSetCf() - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
Returns true if field cf is set (has been assigned a value) and false otherwise
- isSetCfg() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
-
Returns true if field cfg is set (has been assigned a value) and false otherwise
- isSetClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field classLoaderContext is set (has been assigned a value) and false otherwise
- isSetClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
Returns true if field classLoaderContext is set (has been assigned a value) and false otherwise
- isSetClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field classLoaderContext is set (has been assigned a value) and false otherwise
- isSetClassLoaderContext() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field classLoaderContext is set (has been assigned a value) and false otherwise
- isSetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
Returns true if field className is set (has been assigned a value) and false otherwise
- isSetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
Returns true if field className is set (has been assigned a value) and false otherwise
- isSetClassName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
Returns true if field className is set (has been assigned a value) and false otherwise
- isSetClassName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
-
Returns true if field className is set (has been assigned a value) and false otherwise
- isSetClassName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
-
Returns true if field className is set (has been assigned a value) and false otherwise
- isSetClient() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field client is set (has been assigned a value) and false otherwise
- isSetCmid() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
-
Returns true if field cmid is set (has been assigned a value) and false otherwise
- isSetCode() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
-
Returns true if field code is set (has been assigned a value) and false otherwise
- isSetCode() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
-
Returns true if field code is set (has been assigned a value) and false otherwise
- isSetCode() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
-
Returns true if field code is set (has been assigned a value) and false otherwise
- isSetColFamily() - Method in class org.apache.accumulo.core.data.thrift.TKey
-
Returns true if field colFamily is set (has been assigned a value) and false otherwise
- isSetColQualifier() - Method in class org.apache.accumulo.core.data.thrift.TKey
-
Returns true if field colQualifier is set (has been assigned a value) and false otherwise
- isSetColumnFamily() - Method in class org.apache.accumulo.core.data.thrift.TColumn
-
Returns true if field columnFamily is set (has been assigned a value) and false otherwise
- isSetColumnQualifier() - Method in class org.apache.accumulo.core.data.thrift.TColumn
-
Returns true if field columnQualifier is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumns() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field columns is set (has been assigned a value) and false otherwise
- isSetColumnVisibility() - Method in class org.apache.accumulo.core.data.thrift.TColumn
-
Returns true if field columnVisibility is set (has been assigned a value) and false otherwise
- isSetColVisibility() - Method in class org.apache.accumulo.core.data.thrift.TKey
-
Returns true if field colVisibility is set (has been assigned a value) and false otherwise
- isSetConditions() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
-
Returns true if field conditions is set (has been assigned a value) and false otherwise
- isSetConstrainClass() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
-
Returns true if field constrainClass is set (has been assigned a value) and false otherwise
- isSetCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field count is set (has been assigned a value) and false otherwise
- isSetCq() - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
Returns true if field cq is set (has been assigned a value) and false otherwise
- isSetCreationDate() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
-
Returns true if field creationDate is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
Returns true if field credentials is set (has been assigned a value) and false otherwise
- isSetCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
-
Returns true if field current is set (has been assigned a value) and false otherwise
- isSetCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
-
Returns true if field currentLog is set (has been assigned a value) and false otherwise
- isSetCv() - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
Returns true if field cv is set (has been assigned a value) and false otherwise
- isSetCve() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
-
Returns true if field cve is set (has been assigned a value) and false otherwise
- isSetData() - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
Returns true if field data is set (has been assigned a value) and false otherwise
- isSetData() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
-
Returns true if field data is set (has been assigned a value) and false otherwise
- isSetData() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
-
Returns true if field data is set (has been assigned a value) and false otherwise
- isSetDataCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field dataCacheHits is set (has been assigned a value) and false otherwise
- isSetDataCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field dataCacheRequest is set (has been assigned a value) and false otherwise
- isSetDeadTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field deadTabletServers is set (has been assigned a value) and false otherwise
- isSetDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
Returns true if field deleted is set (has been assigned a value) and false otherwise
- isSetDescription() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
-
Returns true if field description is set (has been assigned a value) and false otherwise
- isSetDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
Returns true if field durability is set (has been assigned a value) and false otherwise
- isSetDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
-
Returns true if field durability is set (has been assigned a value) and false otherwise
- isSetDurability() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
Returns true if field durability is set (has been assigned a value) and false otherwise
- isSetE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- isSetE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- isSetE() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
-
Returns true if field e is set (has been assigned a value) and false otherwise
- isSetEdits() - Method in class org.apache.accumulo.core.replication.thrift.WalEdits
-
Returns true if field edits is set (has been assigned a value) and false otherwise
- isSetElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field elapsed is set (has been assigned a value) and false otherwise
- isSetEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
-
Returns true if field endRow is set (has been assigned a value) and false otherwise
- isSetEndRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
Returns true if field endRow is set (has been assigned a value) and false otherwise
- isSetEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
Returns true if field endRow is set (has been assigned a value) and false otherwise
- isSetEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
Returns true if field endRow is set (has been assigned a value) and false otherwise
- isSetEntries() - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
Returns true if field entries is set (has been assigned a value) and false otherwise
- isSetEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field entriesRead is set (has been assigned a value) and false otherwise
- isSetEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field entriesWritten is set (has been assigned a value) and false otherwise
- isSetErrorDir() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Returns true if field errorDir is set (has been assigned a value) and false otherwise
- isSetErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
Returns true if field errors is set (has been assigned a value) and false otherwise
- isSetEstimatedSize() - Method in class org.apache.accumulo.core.data.thrift.MapFileInfo
-
Returns true if field estimatedSize is set (has been assigned a value) and false otherwise
- isSetEx() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
-
Returns true if field ex is set (has been assigned a value) and false otherwise
- isSetExpirationDate() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
-
Returns true if field expirationDate is set (has been assigned a value) and false otherwise
- isSetExpirationDate() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
-
Returns true if field expirationDate is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TooManyFilesException
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.TSampleNotPresentException
-
Returns true if field extent is set (has been assigned a value) and false otherwise
- isSetFail() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field fail is set (has been assigned a value) and false otherwise
- isSetFailedExtents() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
-
Returns true if field failedExtents is set (has been assigned a value) and false otherwise
- isSetFailures() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
Returns true if field failures is set (has been assigned a value) and false otherwise
- isSetFilename() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
-
Returns true if field filename is set (has been assigned a value) and false otherwise
- isSetFilenames() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
-
Returns true if field filenames is set (has been assigned a value) and false otherwise
- isSetFiles() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Returns true if field files is set (has been assigned a value) and false otherwise
- isSetFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
Returns true if field files is set (has been assigned a value) and false otherwise
- isSetFinished() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
Returns true if field finished is set (has been assigned a value) and false otherwise
- isSetFlushID() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
Returns true if field flushID is set (has been assigned a value) and false otherwise
- isSetFlushs() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field flushs is set (has been assigned a value) and false otherwise
- isSetForce() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
-
Returns true if field force is set (has been assigned a value) and false otherwise
- isSetFullScans() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
Returns true if field fullScans is set (has been assigned a value) and false otherwise
- isSetGoal() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
Returns true if field goal is set (has been assigned a value) and false otherwise
- isSetGoalState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field goalState is set (has been assigned a value) and false otherwise
- isSetHasTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
Returns true if field hasTimestamp is set (has been assigned a value) and false otherwise
- isSetHoldTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field holdTime is set (has been assigned a value) and false otherwise
- isSetId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
-
Returns true if field id is set (has been assigned a value) and false otherwise
- isSetIdentifier() - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
-
Returns true if field identifier is set (has been assigned a value) and false otherwise
- isSetIdleTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field idleTime is set (has been assigned a value) and false otherwise
- isSetIndexCacheHits() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field indexCacheHits is set (has been assigned a value) and false otherwise
- isSetIndexCacheRequest() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field indexCacheRequest is set (has been assigned a value) and false otherwise
- isSetInfiniteStartKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
-
Returns true if field infiniteStartKey is set (has been assigned a value) and false otherwise
- isSetInfiniteStopKey() - Method in class org.apache.accumulo.core.data.thrift.TRange
-
Returns true if field infiniteStopKey is set (has been assigned a value) and false otherwise
- isSetIngestByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field ingestByteRate is set (has been assigned a value) and false otherwise
- isSetIngestRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field ingestRate is set (has been assigned a value) and false otherwise
- isSetIngestRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field ingestRate is set (has been assigned a value) and false otherwise
- isSetInputFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field inputFiles is set (has been assigned a value) and false otherwise
- isSetInstanceId() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
-
Returns true if field instanceId is set (has been assigned a value) and false otherwise
- isSetInstanceId() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
-
Returns true if field instanceId is set (has been assigned a value) and false otherwise
- isSetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
Returns true if field interfaceMatch is set (has been assigned a value) and false otherwise
- isSetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
Returns true if field interfaceMatch is set (has been assigned a value) and false otherwise
- isSetInterfaceMatch() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
Returns true if field interfaceMatch is set (has been assigned a value) and false otherwise
- isSetInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
Returns true if field inUse is set (has been assigned a value) and false otherwise
- isSetIsolated() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field isolated is set (has been assigned a value) and false otherwise
- isSetIssueDate() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
-
Returns true if field issueDate is set (has been assigned a value) and false otherwise
- isSetIteratorClass() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
-
Returns true if field iteratorClass is set (has been assigned a value) and false otherwise
- isSetIterators() - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
Returns true if field iterators is set (has been assigned a value) and false otherwise
- isSetIterators() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
-
Returns true if field iterators is set (has been assigned a value) and false otherwise
- isSetIterName() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
-
Returns true if field iterName is set (has been assigned a value) and false otherwise
- isSetKey() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
-
Returns true if field key is set (has been assigned a value) and false otherwise
- isSetKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
-
Returns true if field keyExtent is set (has been assigned a value) and false otherwise
- isSetKeyExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
Returns true if field keyExtent is set (has been assigned a value) and false otherwise
- isSetKeyId() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
-
Returns true if field keyId is set (has been assigned a value) and false otherwise
- isSetKeyId() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
-
Returns true if field keyId is set (has been assigned a value) and false otherwise
- isSetKeyValues() - Method in class org.apache.accumulo.core.replication.thrift.KeyValues
-
Returns true if field keyValues is set (has been assigned a value) and false otherwise
- isSetLast() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
-
Returns true if field last is set (has been assigned a value) and false otherwise
- isSetLastContact() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field lastContact is set (has been assigned a value) and false otherwise
- isSetLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
-
Returns true if field lastLog is set (has been assigned a value) and false otherwise
- isSetLastStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
-
Returns true if field lastStatus is set (has been assigned a value) and false otherwise
- isSetLifetime() - Method in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
-
Returns true if field lifetime is set (has been assigned a value) and false otherwise
- isSetLocalityGroup() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field localityGroup is set (has been assigned a value) and false otherwise
- isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
-
Returns true if field lock is set (has been assigned a value) and false otherwise
- isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
Returns true if field lock is set (has been assigned a value) and false otherwise
- isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
-
Returns true if field lock is set (has been assigned a value) and false otherwise
- isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
Returns true if field lock is set (has been assigned a value) and false otherwise
- isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
Returns true if field lock is set (has been assigned a value) and false otherwise
- isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
-
Returns true if field lock is set (has been assigned a value) and false otherwise
- isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
Returns true if field lock is set (has been assigned a value) and false otherwise
- isSetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
Returns true if field lock is set (has been assigned a value) and false otherwise
- isSetLogSorts() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field logSorts is set (has been assigned a value) and false otherwise
- isSetLogsToWatch() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
-
Returns true if field logsToWatch is set (has been assigned a value) and false otherwise
- isSetLookups() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field lookups is set (has been assigned a value) and false otherwise
- isSetMajors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field majors is set (has been assigned a value) and false otherwise
- isSetMajors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field majors is set (has been assigned a value) and false otherwise
- isSetMaxLoops() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
Returns true if field maxLoops is set (has been assigned a value) and false otherwise
- isSetMinors() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field minors is set (has been assigned a value) and false otherwise
- isSetMinors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field minors is set (has been assigned a value) and false otherwise
- isSetMore() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
Returns true if field more is set (has been assigned a value) and false otherwise
- isSetMore() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
-
Returns true if field more is set (has been assigned a value) and false otherwise
- isSetMutation() - Method in class org.apache.accumulo.core.data.thrift.TConditionalMutation
-
Returns true if field mutation is set (has been assigned a value) and false otherwise
- isSetMutation() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
Returns true if field mutation is set (has been assigned a value) and false otherwise
- isSetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
-
Returns true if field mutations is set (has been assigned a value) and false otherwise
- isSetMutations() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
Returns true if field mutations is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
-
Returns true if field name is set (has been assigned a value) and false otherwise
- isSetNamespaceId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
Returns true if field namespaceId is set (has been assigned a value) and false otherwise
- isSetNewTablets() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
-
Returns true if field newTablets is set (has been assigned a value) and false otherwise
- isSetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
Returns true if field ns is set (has been assigned a value) and false otherwise
- isSetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
Returns true if field ns is set (has been assigned a value) and false otherwise
- isSetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
Returns true if field ns is set (has been assigned a value) and false otherwise
- isSetNs() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
Returns true if field ns is set (has been assigned a value) and false otherwise
- isSetNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
-
Returns true if field ns is set (has been assigned a value) and false otherwise
- isSetNs() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
Returns true if field ns is set (has been assigned a value) and false otherwise
- isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_result
-
Returns true if field nssi is set (has been assigned a value) and false otherwise
- isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
-
Returns true if field nssi is set (has been assigned a value) and false otherwise
- isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
-
Returns true if field nssi is set (has been assigned a value) and false otherwise
- isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
-
Returns true if field nssi is set (has been assigned a value) and false otherwise
- isSetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
Returns true if field nssi is set (has been assigned a value) and false otherwise
- isSetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
Returns true if field nste is set (has been assigned a value) and false otherwise
- isSetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
-
Returns true if field nste is set (has been assigned a value) and false otherwise
- isSetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
-
Returns true if field nste is set (has been assigned a value) and false otherwise
- isSetNste() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
-
Returns true if field nste is set (has been assigned a value) and false otherwise
- isSetNum() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field num is set (has been assigned a value) and false otherwise
- isSetNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
-
Returns true if field numberOfViolatingMutations is set (has been assigned a value) and false otherwise
- isSetNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field numEntries is set (has been assigned a value) and false otherwise
- isSetOldTablet() - Method in class org.apache.accumulo.core.master.thrift.TabletSplit
-
Returns true if field oldTablet is set (has been assigned a value) and false otherwise
- isSetOnlineTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field onlineTablets is set (has been assigned a value) and false otherwise
- isSetOp() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
-
Returns true if field op is set (has been assigned a value) and false otherwise
- isSetOp() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Returns true if field op is set (has been assigned a value) and false otherwise
- isSetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Returns true if field opid is set (has been assigned a value) and false otherwise
- isSetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
-
Returns true if field opid is set (has been assigned a value) and false otherwise
- isSetOpid() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
-
Returns true if field opid is set (has been assigned a value) and false otherwise
- isSetOptions() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Returns true if field options is set (has been assigned a value) and false otherwise
- isSetOptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TSamplerConfiguration
-
Returns true if field options is set (has been assigned a value) and false otherwise
- isSetOsLoad() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field osLoad is set (has been assigned a value) and false otherwise
- isSetOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field outputFile is set (has been assigned a value) and false otherwise
- isSetParentId() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
-
Returns true if field parentId is set (has been assigned a value) and false otherwise
- isSetPartNextKey() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
Returns true if field partNextKey is set (has been assigned a value) and false otherwise
- isSetPartNextKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
Returns true if field partNextKeyInclusive is set (has been assigned a value) and false otherwise
- isSetPartScan() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
Returns true if field partScan is set (has been assigned a value) and false otherwise
- isSetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
Returns true if field password is set (has been assigned a value) and false otherwise
- isSetPassword() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
Returns true if field password is set (has been assigned a value) and false otherwise
- isSetPassword() - Method in class org.apache.accumulo.core.security.thrift.TDelegationToken
-
Returns true if field password is set (has been assigned a value) and false otherwise
- isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
Returns true if field permission is set (has been assigned a value) and false otherwise
- isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
Returns true if field permission is set (has been assigned a value) and false otherwise
- isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
Returns true if field permission is set (has been assigned a value) and false otherwise
- isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
Returns true if field permission is set (has been assigned a value) and false otherwise
- isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
Returns true if field permission is set (has been assigned a value) and false otherwise
- isSetPermission() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
Returns true if field permission is set (has been assigned a value) and false otherwise
- isSetPrevEndRow() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
-
Returns true if field prevEndRow is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPrincipal() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
-
Returns true if field principal is set (has been assigned a value) and false otherwise
- isSetPriority() - Method in class org.apache.accumulo.core.data.thrift.IterInfo
-
Returns true if field priority is set (has been assigned a value) and false otherwise
- isSetPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
-
Returns true if field priority is set (has been assigned a value) and false otherwise
- isSetProgress() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
-
Returns true if field progress is set (has been assigned a value) and false otherwise
- isSetProperties() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
-
Returns true if field properties is set (has been assigned a value) and false otherwise
- isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
-
Returns true if field property is set (has been assigned a value) and false otherwise
- isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
-
Returns true if field property is set (has been assigned a value) and false otherwise
- isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
-
Returns true if field property is set (has been assigned a value) and false otherwise
- isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
Returns true if field property is set (has been assigned a value) and false otherwise
- isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
-
Returns true if field property is set (has been assigned a value) and false otherwise
- isSetProperty() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
Returns true if field property is set (has been assigned a value) and false otherwise
- isSetQueryByteRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field queryByteRate is set (has been assigned a value) and false otherwise
- isSetQueryRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field queryRate is set (has been assigned a value) and false otherwise
- isSetQueryRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field queryRate is set (has been assigned a value) and false otherwise
- isSetQueued() - Method in class org.apache.accumulo.core.master.thrift.Compacting
-
Returns true if field queued is set (has been assigned a value) and false otherwise
- isSetQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field queueSumDev is set (has been assigned a value) and false otherwise
- isSetQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field queueTime is set (has been assigned a value) and false otherwise
- isSetRange() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field range is set (has been assigned a value) and false otherwise
- isSetReadaheadThreshold() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field readaheadThreshold is set (has been assigned a value) and false otherwise
- isSetReason() - Method in exception org.apache.accumulo.core.replication.thrift.RemoteReplicationException
-
Returns true if field reason is set (has been assigned a value) and false otherwise
- isSetReason() - Method in exception org.apache.accumulo.core.replication.thrift.ReplicationCoordinatorException
-
Returns true if field reason is set (has been assigned a value) and false otherwise
- isSetReason() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field reason is set (has been assigned a value) and false otherwise
- isSetRecs() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field recs is set (has been assigned a value) and false otherwise
- isSetRecsInMemory() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field recsInMemory is set (has been assigned a value) and false otherwise
- isSetRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_args
-
Returns true if field remoteTableId is set (has been assigned a value) and false otherwise
- isSetRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_args
-
Returns true if field remoteTableId is set (has been assigned a value) and false otherwise
- isSetRemoteTableId() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_args
-
Returns true if field remoteTableId is set (has been assigned a value) and false otherwise
- isSetRequestTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
Returns true if field requestTime is set (has been assigned a value) and false otherwise
- isSetResponseTime() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field responseTime is set (has been assigned a value) and false otherwise
- isSetResult() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
-
Returns true if field result is set (has been assigned a value) and false otherwise
- isSetResult() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
-
Returns true if field result is set (has been assigned a value) and false otherwise
- isSetResults() - Method in class org.apache.accumulo.core.data.thrift.MultiScanResult
-
Returns true if field results is set (has been assigned a value) and false otherwise
- isSetResults() - Method in class org.apache.accumulo.core.data.thrift.ScanResult
-
Returns true if field results is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.accumulo.core.data.thrift.TKey
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRow() - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
Returns true if field row is set (has been assigned a value) and false otherwise
- isSetRunning() - Method in class org.apache.accumulo.core.master.thrift.Compacting
-
Returns true if field running is set (has been assigned a value) and false otherwise
- isSetRuntime() - Method in class org.apache.accumulo.core.master.thrift.RecoveryStatus
-
Returns true if field runtime is set (has been assigned a value) and false otherwise
- isSetSamplerConfig() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field samplerConfig is set (has been assigned a value) and false otherwise
- isSetSamplerConfig() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field samplerConfig is set (has been assigned a value) and false otherwise
- isSetScanId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field scanId is set (has been assigned a value) and false otherwise
- isSetScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialMultiScan
-
Returns true if field scanID is set (has been assigned a value) and false otherwise
- isSetScanID() - Method in class org.apache.accumulo.core.data.thrift.InitialScan
-
Returns true if field scanID is set (has been assigned a value) and false otherwise
- isSetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
-
Returns true if field scanID is set (has been assigned a value) and false otherwise
- isSetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
-
Returns true if field scanID is set (has been assigned a value) and false otherwise
- isSetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
-
Returns true if field scanID is set (has been assigned a value) and false otherwise
- isSetScanID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
-
Returns true if field scanID is set (has been assigned a value) and false otherwise
- isSetScanRate() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field scanRate is set (has been assigned a value) and false otherwise
- isSetScans() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field scans is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_result
-
Returns true if field sec is set (has been assigned a value) and false otherwise
- isSetSecret() - Method in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
-
Returns true if field secret is set (has been assigned a value) and false otherwise
- isSetServer() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
-
Returns true if field server is set (has been assigned a value) and false otherwise
- isSetServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
-
Returns true if field serverName is set (has been assigned a value) and false otherwise
- isSetServerName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
Returns true if field serverName is set (has been assigned a value) and false otherwise
- isSetServersShuttingDown() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field serversShuttingDown is set (has been assigned a value) and false otherwise
- isSetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
-
Returns true if field sessID is set (has been assigned a value) and false otherwise
- isSetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
Returns true if field sessID is set (has been assigned a value) and false otherwise
- isSetSessID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
-
Returns true if field sessID is set (has been assigned a value) and false otherwise
- isSetSessionId() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
-
Returns true if field sessionId is set (has been assigned a value) and false otherwise
- isSetSetTime() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Returns true if field setTime is set (has been assigned a value) and false otherwise
- isSetSetTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
Returns true if field setTime is set (has been assigned a value) and false otherwise
- isSetSources() - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
Returns true if field sources is set (has been assigned a value) and false otherwise
- isSetSplit() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
-
Returns true if field split is set (has been assigned a value) and false otherwise
- isSetSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field splitCreationTime is set (has been assigned a value) and false otherwise
- isSetSplitPoint() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
-
Returns true if field splitPoint is set (has been assigned a value) and false otherwise
- isSetSplits() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
-
Returns true if field splits is set (has been assigned a value) and false otherwise
- isSetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field ssiList is set (has been assigned a value) and false otherwise
- isSetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field ssiList is set (has been assigned a value) and false otherwise
- isSetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field ssiList is set (has been assigned a value) and false otherwise
- isSetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field ssiList is set (has been assigned a value) and false otherwise
- isSetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field ssio is set (has been assigned a value) and false otherwise
- isSetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field ssio is set (has been assigned a value) and false otherwise
- isSetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field ssio is set (has been assigned a value) and false otherwise
- isSetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field ssio is set (has been assigned a value) and false otherwise
- isSetStart() - Method in class org.apache.accumulo.core.data.thrift.TRange
-
Returns true if field start is set (has been assigned a value) and false otherwise
- isSetStarted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
-
Returns true if field started is set (has been assigned a value) and false otherwise
- isSetStartKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
-
Returns true if field startKeyInclusive is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
Returns true if field startRow is set (has been assigned a value) and false otherwise
- isSetStartTime() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
-
Returns true if field startTime is set (has been assigned a value) and false otherwise
- isSetState() - Method in class org.apache.accumulo.core.master.thrift.BulkImportStatus
-
Returns true if field state is set (has been assigned a value) and false otherwise
- isSetState() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
-
Returns true if field state is set (has been assigned a value) and false otherwise
- isSetState() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field state is set (has been assigned a value) and false otherwise
- isSetState() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field state is set (has been assigned a value) and false otherwise
- isSetStatus() - Method in class org.apache.accumulo.core.data.thrift.TCMResult
-
Returns true if field status is set (has been assigned a value) and false otherwise
- isSetStatus() - Method in class org.apache.accumulo.core.master.thrift.DeadServer
-
Returns true if field status is set (has been assigned a value) and false otherwise
- isSetStatus() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
Returns true if field status is set (has been assigned a value) and false otherwise
- isSetStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field status is set (has been assigned a value) and false otherwise
- isSetStop() - Method in class org.apache.accumulo.core.data.thrift.TRange
-
Returns true if field stop is set (has been assigned a value) and false otherwise
- isSetStopKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
-
Returns true if field stopKeyInclusive is set (has been assigned a value) and false otherwise
- isSetStopTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
-
Returns true if field stopTabletServers is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationCoordinator.getServicerAddress_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateKeyValues_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.replication.thrift.ReplicationServicer.replicateLog_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_result
-
Returns true if field success is set (has been assigned a value) and false otherwise
- isSetSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
-
Returns true if field sumDev is set (has been assigned a value) and false otherwise
- isSetSymbols() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
Returns true if field symbols is set (has been assigned a value) and false otherwise
- isSetSyncs() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field syncs is set (has been assigned a value) and false otherwise
- isSetSysPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
Returns true if field sysPerm is set (has been assigned a value) and false otherwise
- isSetTable() - Method in class org.apache.accumulo.core.data.thrift.TKeyExtent
-
Returns true if field table is set (has been assigned a value) and false otherwise
- isSetTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Returns true if field tableId is set (has been assigned a value) and false otherwise
- isSetTableId() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
Returns true if field tableId is set (has been assigned a value) and false otherwise
- isSetTableId() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
-
Returns true if field tableId is set (has been assigned a value) and false otherwise
- isSetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field tableId is set (has been assigned a value) and false otherwise
- isSetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
Returns true if field tableId is set (has been assigned a value) and false otherwise
- isSetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
Returns true if field tableId is set (has been assigned a value) and false otherwise
- isSetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
-
Returns true if field tableId is set (has been assigned a value) and false otherwise
- isSetTableID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
Returns true if field tableID is set (has been assigned a value) and false otherwise
- isSetTableMap() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field tableMap is set (has been assigned a value) and false otherwise
- isSetTableMap() - Method in class org.apache.accumulo.core.master.thrift.TabletServerStatus
-
Returns true if field tableMap is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTableName() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
Returns true if field tableName is set (has been assigned a value) and false otherwise
- isSetTables() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
-
Returns true if field tables is set (has been assigned a value) and false otherwise
- isSetTables() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
-
Returns true if field tables is set (has been assigned a value) and false otherwise
- isSetTablet() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
Returns true if field tablet is set (has been assigned a value) and false otherwise
- isSetTablets() - Method in class org.apache.accumulo.core.master.thrift.TableInfo
-
Returns true if field tablets is set (has been assigned a value) and false otherwise
- isSetTabletServer() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
-
Returns true if field tabletServer is set (has been assigned a value) and false otherwise
- isSetTblNspcPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
Returns true if field tblNspcPerm is set (has been assigned a value) and false otherwise
- isSetTblPerm() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
Returns true if field tblPerm is set (has been assigned a value) and false otherwise
- isSetTfino() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
-
Returns true if field tfino is set (has been assigned a value) and false otherwise
- isSetTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Returns true if field tid is set (has been assigned a value) and false otherwise
- isSetTid() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
Returns true if field tid is set (has been assigned a value) and false otherwise
- isSetTid() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
Returns true if field tid is set (has been assigned a value) and false otherwise
- isSetTime() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- isSetTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
- isSetTimestamp() - Method in class org.apache.accumulo.core.data.thrift.TKey
-
Returns true if field timestamp is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getActiveTservers_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getDelegationToken_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.getMasterStats_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeSystemProperty_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportSplitExtent_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.reportTabletStatus_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setMasterGoalState_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdownTabletServer_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForBalance_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.bulkImport_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeConditionalUpdate_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeMultiScan_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeScan_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.conditionalUpdate_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveCompactions_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveLogs_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getActiveScans_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getHistoricalStats_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletServerStatus_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.getTabletStats_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.invalidateConditionalUpdate_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.removeLogs_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.splitTablet_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startConditionalUpdate_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startUpdate_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
-
Returns true if field tinfo is set (has been assigned a value) and false otherwise
- isSetTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
Returns true if field tmfe is set (has been assigned a value) and false otherwise
- isSetTmfe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
-
Returns true if field tmfe is set (has been assigned a value) and false otherwise
- isSetToAuth() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
-
Returns true if field toAuth is set (has been assigned a value) and false otherwise
- isSetToe() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
-
Returns true if field toe is set (has been assigned a value) and false otherwise
- isSetToken() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
-
Returns true if field token is set (has been assigned a value) and false otherwise
- isSetTokenClassName() - Method in class org.apache.accumulo.core.security.thrift.TCredentials
-
Returns true if field tokenClassName is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.master.thrift.FateService.waitForFateOperation_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.initiateFlush_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeNamespaceProperty_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.removeTableProperty_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTope() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_result
-
Returns true if field tope is set (has been assigned a value) and false otherwise
- isSetTraceId() - Method in class org.apache.accumulo.core.trace.thrift.TInfo
-
Returns true if field traceId is set (has been assigned a value) and false otherwise
- isSetTs() - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
Returns true if field ts is set (has been assigned a value) and false otherwise
- isSetTServerInfo() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field tServerInfo is set (has been assigned a value) and false otherwise
- isSetTserverLock() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
-
Returns true if field tserverLock is set (has been assigned a value) and false otherwise
- isSetTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueMultiScan_result
-
Returns true if field tsnpe is set (has been assigned a value) and false otherwise
- isSetTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.continueScan_result
-
Returns true if field tsnpe is set (has been assigned a value) and false otherwise
- isSetTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_result
-
Returns true if field tsnpe is set (has been assigned a value) and false otherwise
- isSetTsnpe() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_result
-
Returns true if field tsnpe is set (has been assigned a value) and false otherwise
- isSetTtl() - Method in class org.apache.accumulo.core.data.thrift.TConditionalSession
-
Returns true if field ttl is set (has been assigned a value) and false otherwise
- isSetType() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
-
Returns true if field type is set (has been assigned a value) and false otherwise
- isSetType() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
-
Returns true if field type is set (has been assigned a value) and false otherwise
- isSetType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
-
Returns true if field type is set (has been assigned a value) and false otherwise
- isSetType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field type is set (has been assigned a value) and false otherwise
- isSetUnassignedTablets() - Method in class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Returns true if field unassignedTablets is set (has been assigned a value) and false otherwise
- isSetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
-
Returns true if field updateID is set (has been assigned a value) and false otherwise
- isSetUpdateID() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.closeUpdate_args
-
Returns true if field updateID is set (has been assigned a value) and false otherwise
- isSetUsage() - Method in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
-
Returns true if field usage is set (has been assigned a value) and false otherwise
- isSetUser() - Method in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
-
Returns true if field user is set (has been assigned a value) and false otherwise
- isSetUser() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveScan
-
Returns true if field user is set (has been assigned a value) and false otherwise
- isSetVal() - Method in class org.apache.accumulo.core.data.thrift.TCondition
-
Returns true if field val is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.accumulo.core.data.thrift.TKeyValue
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setNamespaceProperty_args
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setSystemProperty_args
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValue() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.setTableProperty_args
-
Returns true if field value is set (has been assigned a value) and false otherwise
- isSetValues() - Method in class org.apache.accumulo.core.data.thrift.TMutation
-
Returns true if field values is set (has been assigned a value) and false otherwise
- isSetViolationCode() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
-
Returns true if field violationCode is set (has been assigned a value) and false otherwise
- isSetViolationDescription() - Method in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
-
Returns true if field violationDescription is set (has been assigned a value) and false otherwise
- isSetViolationSummaries() - Method in class org.apache.accumulo.core.data.thrift.UpdateErrors
-
Returns true if field violationSummaries is set (has been assigned a value) and false otherwise
- isSetViolationSummaries() - Method in exception org.apache.accumulo.core.tabletserver.thrift.ConstraintViolationException
-
Returns true if field violationSummaries is set (has been assigned a value) and false otherwise
- isSetWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
-
Returns true if field waitForWrites is set (has been assigned a value) and false otherwise
- isSetWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
-
Returns true if field waitForWrites is set (has been assigned a value) and false otherwise
- isSetWhy() - Method in exception org.apache.accumulo.core.master.thrift.RecoveryException
-
Returns true if field why is set (has been assigned a value) and false otherwise
- isSsl() - Method in class org.apache.accumulo.core.client.impl.ThriftTransportKey
- isStartKeyInclusive() - Method in class org.apache.accumulo.core.data.Range
-
Gets whether the start key of this range is inclusive.
- isStartKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
- isStopKeyInclusive() - Method in class org.apache.accumulo.core.data.thrift.TRange
- isStopTabletServers() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.shutdown_args
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- isSuccess() - Method in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- isSuccess() - Method in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_result
- ISSUE_DATE - org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
- issueDate - Variable in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- isSupported() - Method in enum org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
- isSupportedAccumuloProperty(Property) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.impl.FileOutputConfigurator
-
The supported Accumulo properties we set in this OutputFormat, that change the behavior of the RecordWriter.
These properties correspond to the supported public static setter methods available to this class. - isSupportedAccumuloProperty(Property) - Static method in class org.apache.accumulo.core.client.mapreduce.lib.util.FileOutputConfigurator
-
Deprecated.since 1.6.0; Configure your job with the appropriate InputFormat or OutputFormat.
- IsSupportedCompressionAlgorithm() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty.IsSupportedCompressionAlgorithm
- isThrowExceptionOnMissing() - 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
- isTimeSet() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
- isTracing() - Static method in class org.apache.accumulo.core.trace.Trace
-
Returns whether tracing is currently on.
- isTrustStoreSet() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
- isValidEncoding(String) - Static method in class org.apache.accumulo.core.iterators.conf.ColumnSet
- isValidFormat(String) - Method in enum org.apache.accumulo.core.conf.PropertyType
-
Checks if the given value is valid for this type.
- isValidOption(String) - Method in class org.apache.accumulo.core.client.sample.AbstractHashSampler
-
Subclasses with options should override this method and return true if the option is valid for the subclass or if
super.isValidOption(opt)
returns true. - isValidOption(String) - Method in class org.apache.accumulo.core.client.sample.RowColumnSampler
- isValidPath(Path) - Method in class org.apache.accumulo.core.volume.NonConfiguredVolume
- isValidPath(Path) - Method in interface org.apache.accumulo.core.volume.Volume
-
Determine if the Path is valid on this Volume.
- isValidPath(Path) - Method in class org.apache.accumulo.core.volume.VolumeImpl
- isValidPropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
-
Checks if the given property key is valid.
- isValidTablePropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
-
Checks if the given property key is for a valid table property.
- isValidZooPropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
-
Checks if the given property key is valid for a property that may be changed via Zookeeper.
- isWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startMultiScan_args
- isWaitForWrites() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.startScan_args
- iter - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
- ITER_NAME - org.apache.accumulo.core.data.thrift.IterInfo._Fields
- IterationInterruptedException - Exception in org.apache.accumulo.core.iterators
- IterationInterruptedException() - Constructor for exception org.apache.accumulo.core.iterators.IterationInterruptedException
- IterationInterruptedException(String) - Constructor for exception org.apache.accumulo.core.iterators.IterationInterruptedException
- iterator() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
- iterator() - Method in class org.apache.accumulo.core.client.impl.OfflineScanner
- iterator() - Method in class org.apache.accumulo.core.client.impl.ScannerImpl
- iterator() - Method in class org.apache.accumulo.core.client.impl.ScannerOptions
- iterator() - Method in class org.apache.accumulo.core.client.impl.TabletServerBatchReader
- iterator() - Method in class org.apache.accumulo.core.client.IsolatedScanner
- iterator() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
- iterator() - Method in interface org.apache.accumulo.core.client.IsolatedScanner.RowBuffer
- iterator() - Method in class org.apache.accumulo.core.client.mock.MockBatchScanner
-
Deprecated.
- iterator() - Method in class org.apache.accumulo.core.client.mock.MockScanner
-
Deprecated.
- iterator() - Method in class org.apache.accumulo.core.client.mock.MockScannerBase
-
Deprecated.
- iterator() - Method in interface org.apache.accumulo.core.client.ScannerBase
-
Returns an iterator over an accumulo table.
- iterator() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
-
Returns an iterator over property key/value pairs in this configuration.
- iterator() - Method in interface org.apache.accumulo.core.iterators.system.SourceSwitchingIterator.DataSource
- iterator() - Method in class org.apache.accumulo.core.security.Authorizations
- iterator() - Method in class org.apache.accumulo.core.util.PreAllocatedArray
- ITERATOR_CLASS - org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
- IteratorAdapter - Class in org.apache.accumulo.core.client.mock
-
Deprecated.since 1.8.0; use
IteratorAdapter
instead. - IteratorAdapter - Class in org.apache.accumulo.core.iterators
- IteratorAdapter(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.client.mock.IteratorAdapter
-
Deprecated.
- IteratorAdapter(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.IteratorAdapter
- iteratorClass - Variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
- IteratorConfig - Class in org.apache.accumulo.core.tabletserver.thrift
- IteratorConfig() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- IteratorConfig(List<TIteratorSetting>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- IteratorConfig(IteratorConfig) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
-
Performs a deep copy on other.
- IteratorConfig._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.
- IteratorEnvironment - Interface in org.apache.accumulo.core.iterators
- IteratorOptions(String, String, Map<String, String>, List<String>) - Constructor for class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
-
IteratorOptions holds the name, description, and option information for an iterator.
- iterators - Variable in class org.apache.accumulo.core.data.thrift.TCondition
- iterators - Variable in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
- ITERATORS - org.apache.accumulo.core.client.mapreduce.lib.impl.InputConfigurator.ScanOpts
- ITERATORS - org.apache.accumulo.core.client.mapreduce.lib.util.InputConfigurator.ScanOpts
-
Deprecated.
- ITERATORS - org.apache.accumulo.core.data.thrift.TCondition._Fields
- ITERATORS - org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
- IteratorSetting - Class in org.apache.accumulo.core.client
-
Configure an iterator for minc, majc, and/or scan.
- IteratorSetting(int, Class<? extends SortedKeyValueIterator<Key, Value>>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
-
Constructs an iterator setting using the given class's SimpleName for the iterator name.
- IteratorSetting(int, Class<? extends SortedKeyValueIterator<Key, Value>>, Map<String, String>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
-
Constructs an iterator setting using the given class's SimpleName for the iterator name and configured for the specified scopes with the specified parameters.
- IteratorSetting(int, String, Class<? extends SortedKeyValueIterator<Key, Value>>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
-
Constructs an iterator setting configured for the scan scope with no parameters.
- IteratorSetting(int, String, Class<? extends SortedKeyValueIterator<Key, Value>>, Map<String, String>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
-
Constructs an iterator setting using the provided name and the provided class's name for the scan scope with the provided parameters.
- IteratorSetting(int, String, String) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
-
Constructs an iterator setting configured for the scan scope with no parameters.
- IteratorSetting(int, String, String, Map<String, String>) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
-
Constructs an iterator setting configured for the specified scopes with the specified parameters.
- IteratorSetting(DataInput) - Constructor for class org.apache.accumulo.core.client.IteratorSetting
- IteratorSetting.Column - Class in org.apache.accumulo.core.client
-
A convenience class for passing column family and column qualifiers to iterator configuration methods.
- IteratorUtil - Class in org.apache.accumulo.core.iterators
- IteratorUtil() - Constructor for class org.apache.accumulo.core.iterators.IteratorUtil
- IteratorUtil.IteratorScope - Enum in org.apache.accumulo.core.iterators
-
Even though this type is not in a public API package, its used by methods in the public API.
- IteratorUtil.IterInfoComparator - Class in org.apache.accumulo.core.iterators
- IterConfig() - Constructor for class org.apache.accumulo.core.client.impl.CompressedIterators.IterConfig
- IterInfo - Class in org.apache.accumulo.core.data.thrift
- IterInfo() - Constructor for class org.apache.accumulo.core.data.thrift.IterInfo
- IterInfo(int, String, String) - Constructor for class org.apache.accumulo.core.data.thrift.IterInfo
- IterInfo(IterInfo) - Constructor for class org.apache.accumulo.core.data.thrift.IterInfo
-
Performs a deep copy on other.
- IterInfo._Fields - Enum in org.apache.accumulo.core.data.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- IterInfoComparator() - Constructor for class org.apache.accumulo.core.iterators.IteratorUtil.IterInfoComparator
- iterName - Variable in class org.apache.accumulo.core.data.thrift.IterInfo
J
- Jar - Class in org.apache.accumulo.core.util
- Jar() - Constructor for class org.apache.accumulo.core.util.Jar
- JOB - org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.TokenSource
- jobIterators(JobConf, String) - Method in class org.apache.accumulo.core.client.mapred.AbstractInputFormat.AbstractRecordReader
-
Extracts Iterators settings from the context to be used by RecordReader.
- jobIterators(JobConf, String) - Method in class org.apache.accumulo.core.client.mapred.InputFormatBase.RecordReaderBase
K
- kDepth - Static variable in class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
- KE_2_TID_OLD - Static variable in class org.apache.accumulo.core.data.impl.TabletIdImpl
- KERBEROS_SERVER_PRIMARY - org.apache.accumulo.core.client.ClientConfiguration.ClientProperty
- kerberosServerPrimary - Variable in class org.apache.accumulo.core.rpc.SaslConnectionParams
- KerberosToken - Class in org.apache.accumulo.core.client.security.tokens
-
Authentication token for Kerberos authenticated clients
- KerberosToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.KerberosToken
-
Creates a token using the login user as returned by
UserGroupInformation.getCurrentUser()
- KerberosToken(String) - Constructor for class org.apache.accumulo.core.client.security.tokens.KerberosToken
-
Creates a token using the provided principal and the currently logged-in user via
UserGroupInformation
. - KerberosToken(String, File) - Constructor for class org.apache.accumulo.core.client.security.tokens.KerberosToken
-
Creates a Kerberos token for the specified principal using the provided keytab.
- KerberosToken(String, File, boolean) - Constructor for class org.apache.accumulo.core.client.security.tokens.KerberosToken
-
Deprecated.since 1.8.0, @see #KerberosToken(String, File)
- KET - Static variable in class org.apache.accumulo.core.client.impl.Translators
- key - Variable in class org.apache.accumulo.core.data.thrift.TKeyValue
- Key - Class in org.apache.accumulo.core.data
-
This is the Key used to store and access individual values in Accumulo.
- Key() - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with empty row, empty column family, empty column qualifier, empty column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(byte[]) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, empty column family, empty column qualifier, empty column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, empty column qualifier, empty column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(byte[], byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, empty column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(byte[], byte[], byte[], byte[]) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, the specified column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(byte[], byte[], byte[], byte[], long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key.
- Key(byte[], byte[], byte[], byte[], long, boolean) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key.
- Key(byte[], byte[], byte[], byte[], long, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key.
- Key(byte[], byte[], byte[], long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, empty column visibility, the specified timestamp, and delete marker false.
- Key(byte[], byte[], byte[], ColumnVisibility, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, the specified column visibility, the specified timestamp, and delete marker false.
- Key(byte[], int, int, byte[], int, int, byte[], int, int, byte[], int, int, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key.
- Key(byte[], long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, empty column family, empty column qualifier, empty column visibility, the specified timestamp, and delete marker false.
- Key(CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
-
Converts CharSequence to Text and creates a Key using
Key(Text)
. - Key(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
-
Converts CharSequence to Text and creates a Key using
Key(Text,Text)
. - Key(CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
-
Converts CharSequence to Text and creates a Key using
Key(Text,Text,Text)
. - Key(CharSequence, CharSequence, CharSequence, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Converts CharSequence to Text and creates a Key using
Key(Text,Text,Text,long)
. - Key(CharSequence, CharSequence, CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Key
-
Converts CharSequence to Text and creates a Key using
Key(Text,Text,Text,Text)
. - Key(CharSequence, CharSequence, CharSequence, CharSequence, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Converts CharSequence to Text and creates a Key using
Key(Text,Text,Text,Text,long)
. - Key(CharSequence, CharSequence, CharSequence, ColumnVisibility, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Converts CharSequence to Text and creates a Key using
Key(Text,Text,Text,ColumnVisibility,long)
. - Key(Key) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the same row, column family, column qualifier, column visibility, timestamp, and delete marker as the given key.
- Key(TKey) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key from Thrift.
- Key(Text) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, empty column family, empty column qualifier, empty column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(Text, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, empty column family, empty column qualifier, empty column visibility, the specified timestamp, and delete marker false.
- Key(Text, Text) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, empty column qualifier, empty column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(Text, Text, Text) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, empty column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(Text, Text, Text, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, empty column visibility, the specified timestamp, and delete marker false.
- Key(Text, Text, Text, ColumnVisibility, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, the specified column visibility, the specified timestamp, and delete marker false.
- Key(Text, Text, Text, Text) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, the specified column visibility, timestamp
Long.MAX_VALUE
, and delete marker false. - Key(Text, Text, Text, Text, long) - Constructor for class org.apache.accumulo.core.data.Key
-
Creates a key with the specified row, the specified column family, the specified column qualifier, the specified column visibility, the specified timestamp, and delete marker false.
- KEY - org.apache.accumulo.core.data.thrift.TKeyValue._Fields
- KEY_EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args._Fields
- KEY_EXTENT - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args._Fields
- KEY_ID - org.apache.accumulo.core.security.thrift.TAuthenticationKey._Fields
- KEY_ID - org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier._Fields
- KEY_VALUES - org.apache.accumulo.core.replication.thrift.KeyValues._Fields
- keyExtent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.applyUpdates_args
- keyExtent - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.update_args
- KeyExtent - Class in org.apache.accumulo.core.data.impl
-
keeps track of information needed to identify a tablet
- KeyExtent - Class in org.apache.accumulo.core.data
-
Deprecated.since 1.7.0 use
TabletId
- KeyExtent() - Constructor for class org.apache.accumulo.core.data.impl.KeyExtent
-
Default constructor
- KeyExtent() - Constructor for class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- KeyExtent(String, Text, Text) - Constructor for class org.apache.accumulo.core.data.impl.KeyExtent
- KeyExtent(KeyExtent) - Constructor for class org.apache.accumulo.core.data.impl.KeyExtent
- KeyExtent(KeyExtent) - Constructor for class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- KeyExtent(TKeyExtent) - Constructor for class org.apache.accumulo.core.data.impl.KeyExtent
- KeyExtent(TKeyExtent) - Constructor for class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- KeyExtent(Text, Value) - Constructor for class org.apache.accumulo.core.data.impl.KeyExtent
- KeyExtent(Text, Value) - Constructor for class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- KeyExtent(Text, Text) - Constructor for class org.apache.accumulo.core.data.impl.KeyExtent
- KeyExtent(Text, Text) - Constructor for class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- KeyExtent(Text, Text, Text) - Constructor for class org.apache.accumulo.core.data.KeyExtent
-
Deprecated.
- KeyExtentTranslator() - Constructor for class org.apache.accumulo.core.client.impl.Translator.KeyExtentTranslator
- KeyFunctor - Interface in org.apache.accumulo.core.file.keyfunctor
- keyId - Variable in class org.apache.accumulo.core.security.thrift.TAuthenticationKey
- keyId - Variable in class org.apache.accumulo.core.security.thrift.TAuthenticationTokenIdentifier
- keyPos - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
- KeyRangePartitioner - Class in org.apache.accumulo.core.client.mapreduce.lib.partition
-
Hadoop partitioner that uses ranges based on row keys, and optionally sub-bins based on hashing.
- KeyRangePartitioner() - Constructor for class org.apache.accumulo.core.client.mapreduce.lib.partition.KeyRangePartitioner
- keys - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
- keySet() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
- keySet() - Method in class org.apache.accumulo.core.util.MapCounter
- KeyShortener - Class in org.apache.accumulo.core.file.rfile
-
Code to shorten keys that will be placed into RFile indexes.
- keytabPath - Variable in class org.apache.accumulo.core.cli.ClientOpts
- KeyValue - Class in org.apache.accumulo.core.data
-
A key/value pair.
- KeyValue(Key, byte[]) - Constructor for class org.apache.accumulo.core.data.KeyValue
-
Creates a new key/value pair.
- KeyValue(Key, ByteBuffer) - Constructor for class org.apache.accumulo.core.data.KeyValue
-
Creates a new key/value pair.
- KeyValue(Key, Value) - Constructor for class org.apache.accumulo.core.data.KeyValue
-
Creates a new key/value pair.
- keyValues - Variable in class org.apache.accumulo.core.replication.thrift.KeyValues
- KeyValues - Class in org.apache.accumulo.core.replication.thrift
- KeyValues() - Constructor for class org.apache.accumulo.core.replication.thrift.KeyValues
- KeyValues(List<TKeyValue>) - Constructor for class org.apache.accumulo.core.replication.thrift.KeyValues
- KeyValues(KeyValues) - Constructor for class org.apache.accumulo.core.replication.thrift.KeyValues
-
Performs a deep copy on other.
- KeyValues._Fields - Enum in org.apache.accumulo.core.replication.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- keyword() - Method in class org.apache.accumulo.core.file.rfile.PrintInfo
- keyword() - Method in class org.apache.accumulo.core.util.Classpath
- keyword() - Method in class org.apache.accumulo.core.util.CreateToken
- keyword() - Method in class org.apache.accumulo.core.util.Help
- keyword() - Method in class org.apache.accumulo.core.util.Jar
- keyword() - Method in class org.apache.accumulo.core.util.Version
L
- LargeRowFilter - Class in org.apache.accumulo.core.iterators
-
Deprecated.since 1.4, replaced by
LargeRowFilter
- LargeRowFilter - Class in org.apache.accumulo.core.iterators.user
-
This iterator suppresses rows that exceed a specified number of columns.
- LargeRowFilter() - Constructor for class org.apache.accumulo.core.iterators.LargeRowFilter
-
Deprecated.
- LargeRowFilter() - Constructor for class org.apache.accumulo.core.iterators.user.LargeRowFilter
- last - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
- LAST - org.apache.accumulo.core.gc.thrift.GCStatus._Fields
- LAST_CONTACT - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- LAST_LOG - org.apache.accumulo.core.gc.thrift.GCStatus._Fields
- LAST_STATUS - org.apache.accumulo.core.master.thrift.DeadServer._Fields
- lastContact - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- LastLocationColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LastLocationColumnFamily
- lastLog - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
- lastStatus - Variable in class org.apache.accumulo.core.master.thrift.DeadServer
- lastTabletRow - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- length - Variable in class org.apache.accumulo.core.data.ArrayByteSequence
- length - Variable in class org.apache.accumulo.core.util.PreAllocatedArray
- length() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
- length() - Method in class org.apache.accumulo.core.data.ByteSequence
-
Gets the length of this sequence.
- Lexicoder<T> - Interface in org.apache.accumulo.core.client.lexicoder
-
A lexicoder provides methods to convert to/from byte arrays.
- lifetime - Variable in class org.apache.accumulo.core.security.thrift.TDelegationTokenConfig
- LIFETIME - org.apache.accumulo.core.security.thrift.TDelegationTokenConfig._Fields
- limit(ScannerBase) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.OrderSection
-
Limit the scanner to only return Order records
- limit(ScannerBase) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.StatusSection
-
Limit the scanner to only return Status records
- limit(ScannerBase) - Static method in class org.apache.accumulo.core.replication.ReplicationSchema.WorkSection
-
Limit the scanner to only pull replication work records
- list() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Retrieve a list of namespaces in Accumulo.
- list() - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Retrieve a list of tables in Accumulo.
- list() - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsImpl
- list() - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- listConstraints(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
List constraints on a namespace with their assigned numbers.
- listConstraints(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
List constraints on a table with their assigned numbers.
- listConstraints(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
- listConstraints(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
- listIterators(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
-
Get a list of iterators for this namespace.
- listIterators(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Get a list of iterators for this table.
- listIterators(String) - Method in class org.apache.accumulo.core.client.impl.NamespaceOperationsHelper
- listIterators(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsHelper
- ListLexicoder<LT> - Class in org.apache.accumulo.core.client.lexicoder
-
A lexicoder to encode/decode a Java List to/from a byte array where the concatenation of each encoded element sorts lexicographically.
- ListLexicoder(Lexicoder<LT>) - Constructor for class org.apache.accumulo.core.client.lexicoder.ListLexicoder
- listLocalUsers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncProcessor.listLocalUsers
- listLocalUsers() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.Processor.listLocalUsers
- listLocalUsers() - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Return a list of users in accumulo
- listLocalUsers() - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
- listLocalUsers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.Client
- listLocalUsers(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.Iface
- listLocalUsers(TInfo, TCredentials, AsyncMethodCallback) - Method in class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient
- listLocalUsers(TInfo, TCredentials, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncIface
- listLocalUsers_args() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- listLocalUsers_args(ClientService.listLocalUsers_args) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
-
Performs a deep copy on other.
- listLocalUsers_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- listLocalUsers_call(TInfo, TCredentials, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.AsyncClient.listLocalUsers_call
- listLocalUsers_result() - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- listLocalUsers_result(Set<String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- listLocalUsers_result(ClientService.listLocalUsers_result) - Constructor for class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
-
Performs a deep copy on other.
- listSplits(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
- listSplits(String) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- listSplits(String, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
- listSplits(String, int) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- ListTranslator(Translator<IT, OT>) - Constructor for class org.apache.accumulo.core.client.impl.Translator.ListTranslator
- listUsers() - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
-
Deprecated.since 1.5.0; use
SecurityOperations.listLocalUsers()
or the user management functions of your configured authenticator instead. - listUsers() - Method in class org.apache.accumulo.core.client.impl.SecurityOperationsImpl
-
Deprecated.
- LOAD_FAILURE - org.apache.accumulo.core.master.thrift.TabletLoadState
- loadDefault() - Static method in class org.apache.accumulo.core.client.ClientConfiguration
-
Attempts to load a configuration file from the system using the default search paths.
- LOADED - org.apache.accumulo.core.master.thrift.TabletLoadState
- LOADING - org.apache.accumulo.core.master.thrift.BulkImportState
- loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, List<IteratorSetting>, IteratorEnvironment) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, List<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, List<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment, boolean) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, List<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment, boolean, String) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- loadIterators(IteratorUtil.IteratorScope, SortedKeyValueIterator<K, V>, KeyExtent, AccumuloConfiguration, IteratorEnvironment) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- loadIterators(SortedKeyValueIterator<K, V>, Collection<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment, boolean, String) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- loadIterators(SortedKeyValueIterator<K, V>, Collection<IterInfo>, Map<String, Map<String, String>>, IteratorEnvironment, boolean, String, Map<String, Class<? extends SortedKeyValueIterator<K, V>>>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- loadTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncProcessor.loadTablet
- loadTablet() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Processor.loadTablet
- loadTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Client
- loadTablet(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.Iface
- loadTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient
- loadTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncIface
- loadTablet_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- loadTablet_args(TabletClientService.loadTablet_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
-
Performs a deep copy on other.
- loadTablet_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- loadTablet_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.AsyncClient.loadTablet_call
- LOCALITY_GROUP - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
- LOCALITY_GROUPS - Static variable in class org.apache.accumulo.core.replication.ReplicationTable
- localityGroup - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
- LocalityGroup(Map<ByteSequence, MutableLong>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
- LocalityGroup(InterruptibleIterator, Map<ByteSequence, MutableLong>, boolean) - Constructor for class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroup
- LocalityGroupContext(LocalityGroupIterator.LocalityGroup[]) - Constructor for class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroupContext
- LocalityGroupIterator - Class in org.apache.accumulo.core.iterators.system
- LocalityGroupIterator(LocalityGroupIterator.LocalityGroup[]) - Constructor for class org.apache.accumulo.core.iterators.system.LocalityGroupIterator
- LocalityGroupIterator.LocalityGroup - Class in org.apache.accumulo.core.iterators.system
- LocalityGroupIterator.LocalityGroupContext - Class in org.apache.accumulo.core.iterators.system
- LocalityGroupIterator.LocalityGroupSeekCache - Class in org.apache.accumulo.core.iterators.system
-
This will cache the arguments used in the seek call along with the locality groups seeked.
- localityGroups - Variable in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
- LocalityGroupSeekCache() - Constructor for class org.apache.accumulo.core.iterators.system.LocalityGroupIterator.LocalityGroupSeekCache
- LocalityGroupUtil - Class in org.apache.accumulo.core.util
- LocalityGroupUtil() - Constructor for class org.apache.accumulo.core.util.LocalityGroupUtil
- LocalityGroupUtil.LocalityGroupConfigurationError - Exception in org.apache.accumulo.core.util
- LocalityGroupUtil.PartitionedMutation - Class in org.apache.accumulo.core.util
- LocalityGroupUtil.Partitioner - Class in org.apache.accumulo.core.util
- locate(String, Collection<Range>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Locates the tablet servers and tablets that would service a collections of ranges.
- locate(String, Collection<Range>) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.RootTabletLocator
- locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.SyncingTabletLocator
- locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TabletLocator
- locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.impl.TimeoutTabletLocator
- locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.client.mock.impl.MockTabletLocator
-
Deprecated.
- locationObtainer - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- Locations - Interface in org.apache.accumulo.core.client.admin
-
A snapshot of metadata information about where a specified set of ranges are located returned by
TableOperations.locate(String, java.util.Collection)
- lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args
- lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args
- lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args
- lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args
- lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args
- lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args
- lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args
- lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args
- LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.chop_args._Fields
- LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.compact_args._Fields
- LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.fastHalt_args._Fields
- LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flush_args._Fields
- LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.flushTablet_args._Fields
- LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.halt_args._Fields
- LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.loadTablet_args._Fields
- LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletClientService.unloadTablet_args._Fields
- LOCK_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
-
Holds lock IDs to enable a sanity check to ensure that the TServer writing to the metadata tablet is not dead
- log - Static variable in class org.apache.accumulo.core.client.mapred.AbstractInputFormat
- log - Static variable in class org.apache.accumulo.core.client.mapred.AccumuloFileOutputFormat
- log - Static variable in class org.apache.accumulo.core.client.mapred.AccumuloOutputFormat
- log - Static variable in class org.apache.accumulo.core.client.mapreduce.AbstractInputFormat
- log - Static variable in class org.apache.accumulo.core.client.mapreduce.AccumuloFileOutputFormat
- log - Static variable in class org.apache.accumulo.core.client.mapreduce.AccumuloOutputFormat
- log - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
- LOG - org.apache.accumulo.core.client.Durability
-
Write mutations the the write-ahead log.
- LOG - org.apache.accumulo.core.tabletserver.thrift.TDurability
- LOG_LEVEL - org.apache.accumulo.core.client.mapreduce.lib.impl.ConfiguratorBase.GeneralOpts
- LOG_LEVEL - org.apache.accumulo.core.client.mapreduce.lib.util.ConfiguratorBase.GeneralOpts
-
Deprecated.
- LOG_SORTS - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- LogColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LogColumnFamily
- LogEntry - Class in org.apache.accumulo.core.tabletserver.log
- LogEntry(KeyExtent, long, String, String) - Constructor for class org.apache.accumulo.core.tabletserver.log.LogEntry
- LogEntry(LogEntry) - Constructor for class org.apache.accumulo.core.tabletserver.log.LogEntry
- LOGICAL - org.apache.accumulo.core.client.admin.TimeType
-
Used to guarantee ordering of data sequentially as inserted
- loginProps - Variable in class org.apache.accumulo.core.cli.ClientOpts
- LOGS_TO_WATCH - org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args._Fields
- logSorts - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- logStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
- logsToWatch - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.drainReplicationTable_args
- longArrayToBytes(long[]) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumArraySummation
-
Deprecated.
- LongCombiner - Class in org.apache.accumulo.core.iterators
-
A TypedValueCombiner that translates each Value to a Long before reducing, then encodes the reduced Long back to a Value.
- LongCombiner() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner
- LongCombiner.FixedLenEncoder - Class in org.apache.accumulo.core.iterators
-
An Encoder that uses an 8-byte encoding for Longs.
- LongCombiner.StringEncoder - Class in org.apache.accumulo.core.iterators
-
An Encoder that uses a String representation of Longs.
- LongCombiner.Type - Enum in org.apache.accumulo.core.iterators
- LongCombiner.VarLenEncoder - Class in org.apache.accumulo.core.iterators
-
An Encoder that uses a variable-length encoding for Longs.
- LongLexicoder - Class in org.apache.accumulo.core.client.lexicoder
-
Signed long lexicoder.
- LongLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.LongLexicoder
- LongSummation - Class in org.apache.accumulo.core.iterators.aggregation
-
Deprecated.since 1.4, replaced by
SummingCombiner
withLongCombiner.Type.FIXEDLEN
- LongSummation() - Constructor for class org.apache.accumulo.core.iterators.aggregation.LongSummation
-
Deprecated.
- longToBytes(long) - Static method in class org.apache.accumulo.core.iterators.aggregation.LongSummation
-
Deprecated.
- longToBytes(long) - Static method in class org.apache.accumulo.core.iterators.aggregation.NumSummation
-
Deprecated.
- lookup(Key) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
- lookupInstanceName(ZooCache, UUID) - Static method in class org.apache.accumulo.core.client.impl.InstanceOperationsImpl
-
Given a zooCache and instanceId, look up the instance name.
- lookupInstanceName(ZooCache, UUID) - Static method in class org.apache.accumulo.core.client.ZooKeeperInstance
-
Deprecated.since 1.7.0
ZooCache
is not part of the public API, but its a parameter to this method. Therefore code that uses this method is not guaranteed to be stable. This method was deprecated to discourage its use. - lookups - Variable in class org.apache.accumulo.core.master.thrift.TabletServerStatus
- LOOKUPS - org.apache.accumulo.core.master.thrift.TabletServerStatus._Fields
- lookupTablet(ClientContext, TabletLocator.TabletLocation, Text, Text, TabletLocator) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletLocationObtainer
- lookupTablet(ClientContext, TabletLocator.TabletLocation, Text, Text, TabletLocator) - Method in class org.apache.accumulo.core.metadata.MetadataLocationObtainer
- lookupTablets(ClientContext, String, Map<KeyExtent, List<Range>>, TabletLocator) - Method in interface org.apache.accumulo.core.client.impl.TabletLocatorImpl.TabletLocationObtainer
- lookupTablets(ClientContext, String, Map<KeyExtent, List<Range>>, TabletLocator) - Method in class org.apache.accumulo.core.metadata.MetadataLocationObtainer
- LOSSY - Static variable in class org.apache.accumulo.core.iterators.TypedValueCombiner
- lowerBound(List<? extends T>, T, Comparator<? super T>) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
-
Lower bound binary search.
- LruBlockCache - Class in org.apache.accumulo.core.file.blockfile.cache
-
A block cache implementation that is memory-aware using
HeapSize
, memory-bound using an LRU eviction algorithm, and concurrent: backed by aConcurrentHashMap
and with a non-blocking eviction thread giving constant-timeLruBlockCache.cacheBlock(java.lang.String, byte[], boolean)
andLruBlockCache.getBlock(java.lang.String)
operations. - LruBlockCache(long, long) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Default constructor.
- LruBlockCache(long, long, EnumSet<LruBlockCache.Options>) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Constructor used for testing.
- LruBlockCache(long, long, EnumSet<LruBlockCache.Options>, int, float, int, float, float, float, float, float) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.LruBlockCache
-
Configurable constructor.
- LruBlockCache.CacheStats - Class in org.apache.accumulo.core.file.blockfile.cache
- LruBlockCache.Options - Enum in org.apache.accumulo.core.file.blockfile.cache
- LZO - org.apache.accumulo.core.file.rfile.bcfile.Compression.Algorithm
M
- main(String[]) - Static method in class org.apache.accumulo.core.conf.ConfigurationDocGen
-
Generates documentation for conf/accumulo-site.xml file usage.
- main(String[]) - Static method in class org.apache.accumulo.core.file.BloomFilterLayer
- main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.PrintInfo
- main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.CreateEmpty
- main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.PrintInfo
- main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.SplitLarge
- main(String[]) - Static method in class org.apache.accumulo.core.util.CreateToken
- main(String[]) - Static method in class org.apache.accumulo.core.util.Merge
- majc - org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
- MAJOR - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
-
compaction that merges a subset of a tablets files into one file
- MAJOR - org.apache.accumulo.core.tabletserver.thrift.CompactionType
- majors - Variable in class org.apache.accumulo.core.master.thrift.TableInfo
- majors - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
- MAJORS - org.apache.accumulo.core.master.thrift.TableInfo._Fields
- MAJORS - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
- makeMockInstance(String) - Static method in class org.apache.accumulo.core.util.DeprecationUtil
- makeMockLocator() - Static method in class org.apache.accumulo.core.util.DeprecationUtil
- MAP_ENTRY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.ClassSize
-
Overhead for entry in map
- MapCounter<KT> - Class in org.apache.accumulo.core.util
- MapCounter() - Constructor for class org.apache.accumulo.core.util.MapCounter
- MAPFILE_EXTENSION - Static variable in class org.apache.accumulo.core.Constants
- MapFileInfo - Class in org.apache.accumulo.core.data.thrift
- MapFileInfo() - Constructor for class org.apache.accumulo.core.data.thrift.MapFileInfo
- MapFileInfo(long) - Constructor for class org.apache.accumulo.core.data.thrift.MapFileInfo
- MapFileInfo(MapFileInfo) - Constructor for class org.apache.accumulo.core.data.thrift.MapFileInfo
-
Performs a deep copy on other.
- MapFileInfo._Fields - Enum in org.apache.accumulo.core.data.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MapFileIterator - Class in org.apache.accumulo.core.iterators.system
- MapFileIterator(AccumuloConfiguration, FileSystem, String, Configuration) - Constructor for class org.apache.accumulo.core.iterators.system.MapFileIterator
- MapFileOperations - Class in org.apache.accumulo.core.file.map
- MapFileOperations() - Constructor for class org.apache.accumulo.core.file.map.MapFileOperations
- MapFileOperations.RangeIterator - Class in org.apache.accumulo.core.file.map
- MapFileUtil - Class in org.apache.accumulo.core.file.map
- MapFileUtil() - Constructor for class org.apache.accumulo.core.file.map.MapFileUtil
- MapReduceClientOnDefaultTable - Class in org.apache.accumulo.core.cli
- MapReduceClientOnDefaultTable(String) - Constructor for class org.apache.accumulo.core.cli.MapReduceClientOnDefaultTable
- MapReduceClientOnRequiredTable - Class in org.apache.accumulo.core.cli
- MapReduceClientOnRequiredTable() - Constructor for class org.apache.accumulo.core.cli.MapReduceClientOnRequiredTable
- MapReduceClientOpts - Class in org.apache.accumulo.core.cli
-
Adds some MR awareness to the ClientOpts
- MapReduceClientOpts() - Constructor for class org.apache.accumulo.core.cli.MapReduceClientOpts
- mark(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
- mark(int) - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
- mark(int) - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
- markSupported() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
- markSupported() - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
- markSupported() - Method in class org.apache.accumulo.core.security.crypto.BlockedInputStream
- MASTER_BULK_RENAME_THREADS - org.apache.accumulo.core.conf.Property
- MASTER_BULK_RETRIES - org.apache.accumulo.core.conf.Property
- MASTER_BULK_THREADPOOL_SIZE - org.apache.accumulo.core.conf.Property
- MASTER_BULK_TIMEOUT - org.apache.accumulo.core.conf.Property
- MASTER_CLIENTPORT - org.apache.accumulo.core.conf.Property
- MASTER_FATE_METRICS_ENABLED - org.apache.accumulo.core.conf.Property
- MASTER_FATE_METRICS_MIN_UPDATE_INTERVAL - org.apache.accumulo.core.conf.Property
- MASTER_FATE_THREADPOOL_SIZE - org.apache.accumulo.core.conf.Property
- MASTER_LEASE_RECOVERY_WAITING_PERIOD - org.apache.accumulo.core.conf.Property
- MASTER_METADATA_SUSPENDABLE - org.apache.accumulo.core.conf.Property
- MASTER_MINTHREADS - org.apache.accumulo.core.conf.Property
- MASTER_PREFIX - org.apache.accumulo.core.conf.Property
- MASTER_RECOVERY_DELAY - org.apache.accumulo.core.conf.Property
- MASTER_RECOVERY_MAXAGE - org.apache.accumulo.core.conf.Property
- MASTER_RECOVERY_MAXTIME - org.apache.accumulo.core.conf.Property
- MASTER_REPLICATION_COORDINATOR_MINTHREADS - org.apache.accumulo.core.conf.Property
- MASTER_REPLICATION_COORDINATOR_PORT - org.apache.accumulo.core.conf.Property
- MASTER_REPLICATION_COORDINATOR_THREADCHECK - org.apache.accumulo.core.conf.Property
- MASTER_REPLICATION_SCAN_INTERVAL - org.apache.accumulo.core.conf.Property
- MASTER_STARTUP_TSERVER_AVAIL_MAX_WAIT - org.apache.accumulo.core.conf.Property
- MASTER_STARTUP_TSERVER_AVAIL_MIN_COUNT - org.apache.accumulo.core.conf.Property
- MASTER_STATUS_THREAD_POOL_SIZE - org.apache.accumulo.core.conf.Property
- MASTER_TABLET_BALANCER - org.apache.accumulo.core.conf.Property
- MASTER_THREADCHECK - org.apache.accumulo.core.conf.Property
- MASTER_WALOG_CLOSER_IMPLEMETATION - org.apache.accumulo.core.conf.Property
- MasterClient - Class in org.apache.accumulo.core.client.impl
- MasterClient() - Constructor for class org.apache.accumulo.core.client.impl.MasterClient
- MasterClientService - Class in org.apache.accumulo.core.master.thrift
- MasterClientService() - Constructor for class org.apache.accumulo.core.master.thrift.MasterClientService
- MasterClientService.AsyncClient - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.drainReplicationTable_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.getActiveTservers_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.getDelegationToken_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.getMasterStats_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.initiateFlush_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.removeNamespaceProperty_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.removeSystemProperty_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.removeTableProperty_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.reportSplitExtent_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.reportTabletStatus_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.setMasterGoalState_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.setNamespaceProperty_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.setSystemProperty_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.setTableProperty_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.shutdown_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.shutdownTabletServer_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.waitForBalance_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncClient.waitForFlush_call - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncIface - Interface in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.drainReplicationTable<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.getActiveTservers<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.getDelegationToken<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.getMasterStats<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.initiateFlush<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.removeNamespaceProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.removeSystemProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.removeTableProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.reportSplitExtent<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.reportTabletStatus<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.setMasterGoalState<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.setNamespaceProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.setSystemProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.setTableProperty<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.shutdown<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.shutdownTabletServer<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.waitForBalance<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.AsyncProcessor.waitForFlush<I extends MasterClientService.AsyncIface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Client - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Client.Factory - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.drainReplicationTable_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.drainReplicationTable_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.drainReplicationTable_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.drainReplicationTable_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.getActiveTservers_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.getActiveTservers_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.getActiveTservers_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.getActiveTservers_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.getDelegationToken_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.getDelegationToken_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.getDelegationToken_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.getDelegationToken_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.getMasterStats_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.getMasterStats_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.getMasterStats_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.getMasterStats_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.Iface - Interface in org.apache.accumulo.core.master.thrift
- MasterClientService.initiateFlush_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.initiateFlush_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.initiateFlush_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.initiateFlush_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.Processor<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.drainReplicationTable<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.getActiveTservers<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.getDelegationToken<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.getMasterStats<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.initiateFlush<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.removeNamespaceProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.removeSystemProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.removeTableProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.reportSplitExtent<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.reportTabletStatus<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.setMasterGoalState<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.setNamespaceProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.setSystemProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.setTableProperty<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.shutdown<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.shutdownTabletServer<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.waitForBalance<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.Processor.waitForFlush<I extends MasterClientService.Iface> - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.removeNamespaceProperty_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.removeNamespaceProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.removeNamespaceProperty_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.removeNamespaceProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.removeSystemProperty_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.removeSystemProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.removeSystemProperty_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.removeSystemProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.removeTableProperty_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.removeTableProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.removeTableProperty_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.removeTableProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.reportSplitExtent_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.reportSplitExtent_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.reportTabletStatus_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.reportTabletStatus_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.setMasterGoalState_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.setMasterGoalState_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.setMasterGoalState_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.setMasterGoalState_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.setNamespaceProperty_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.setNamespaceProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.setNamespaceProperty_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.setNamespaceProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.setSystemProperty_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.setSystemProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.setSystemProperty_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.setSystemProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.setTableProperty_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.setTableProperty_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.setTableProperty_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.setTableProperty_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.shutdown_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.shutdown_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.shutdown_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.shutdown_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.shutdownTabletServer_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.shutdownTabletServer_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.shutdownTabletServer_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.shutdownTabletServer_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.waitForBalance_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.waitForBalance_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.waitForBalance_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.waitForBalance_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.waitForFlush_args - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.waitForFlush_args._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterClientService.waitForFlush_result - Class in org.apache.accumulo.core.master.thrift
- MasterClientService.waitForFlush_result._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterGoalState - Enum in org.apache.accumulo.core.master.thrift
- MasterMonitorInfo - Class in org.apache.accumulo.core.master.thrift
- MasterMonitorInfo() - Constructor for class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- MasterMonitorInfo(Map<String, TableInfo>, List<TabletServerStatus>, Map<String, Byte>, MasterState, MasterGoalState, int, Set<String>, List<DeadServer>, List<BulkImportStatus>) - Constructor for class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
- MasterMonitorInfo(MasterMonitorInfo) - Constructor for class org.apache.accumulo.core.master.thrift.MasterMonitorInfo
-
Performs a deep copy on other.
- MasterMonitorInfo._Fields - Enum in org.apache.accumulo.core.master.thrift
-
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
- MasterState - Enum in org.apache.accumulo.core.master.thrift
- match(byte[]) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
- match(ByteSequence) - Method in class org.apache.accumulo.core.iterators.user.GrepIterator
- MATCH_SUBSTRING - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
- MatchFilter(String) - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration.MatchFilter
-
Creates a new filter.
- MAX__KEY_SIZE_EXCEEDED_VIOLATION - Static variable in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
- MAX_BUFFER_SIZE_OPT - Static variable in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
- MAX_BUFFER_SIZE_OPT - Static variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
- MAX_CF_IN_DLG - Static variable in class org.apache.accumulo.core.file.rfile.RFile.Writer
- MAX_DATA_TO_PRINT - Static variable in class org.apache.accumulo.core.Constants
- MAX_LOOPS - org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args._Fields
- MaxCombiner - Class in org.apache.accumulo.core.iterators.user
-
A Combiner that interprets Values as Longs and returns the largest Long among them.
- MaxCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.MaxCombiner
- maximizeStartKeyTimeStamp(Range) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- maxLoops - Variable in class org.apache.accumulo.core.master.thrift.MasterClientService.waitForFlush_args
- maxSize - Static variable in class org.apache.accumulo.core.constraints.DefaultKeySizeConstraint
- maxVersions - Variable in class org.apache.accumulo.core.iterators.user.VersioningIterator
- mechanism - Variable in class org.apache.accumulo.core.rpc.SaslConnectionParams
- membershipTest(Key) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
- membershipTest(Key) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
- membershipTest(Key) - Method in class org.apache.accumulo.core.bloomfilter.Filter
-
Determines whether a specified key belongs to this filter.
- MEMORY - org.apache.accumulo.core.conf.PropertyType
- MemoryConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.MemoryConverter
- MemoryRowBuffer() - Constructor for class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBuffer
- MemoryRowBufferFactory() - Constructor for class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBufferFactory
- merge(String, Text, Text) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
-
Merge tablets between (start, end]
- merge(String, Text, Text) - Method in class org.apache.accumulo.core.client.impl.TableOperationsImpl
- merge(String, Text, Text) - Method in class org.apache.accumulo.core.client.mock.MockAccumulo
-
Deprecated.
- merge(Connector, String, List<Merge.Size>, int) - Method in class org.apache.accumulo.core.util.Merge
- merge(Text, Text) - Method in class org.apache.accumulo.core.client.mock.MockTable
-
Deprecated.
- Merge - Class in org.apache.accumulo.core.util
- Merge() - Constructor for class org.apache.accumulo.core.util.Merge
- MERGE - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
-
compaction to flush a tablets memory and merge it with the tablets smallest file.
- MERGE - org.apache.accumulo.core.client.impl.thrift.TableOperation
- MERGE - org.apache.accumulo.core.tabletserver.thrift.CompactionType
- Merge.MergeException - Exception in org.apache.accumulo.core.util
- Merge.Size - Class in org.apache.accumulo.core.util
- mergeIteratorConfig(List<IterInfo>, Map<String, Map<String, String>>, List<IterInfo>, Map<String, Map<String, String>>, List<IterInfo>, Map<String, Map<String, String>>) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
- mergeMany(Connector, String, List<Merge.Size>, long, boolean, boolean) - Method in class org.apache.accumulo.core.util.Merge
- mergeOverlapping(Collection<Range>) - Static method in class org.apache.accumulo.core.data.Range
-
Merges overlapping and adjacent ranges.
- mergeSome(Connector, String, List<Merge.Size>, int) - Method in class org.apache.accumulo.core.util.Merge
- mergomatic(Connector, String, Text, Text, long, boolean) - Method in class org.apache.accumulo.core.util.Merge
- message(String, Object...) - Method in class org.apache.accumulo.core.util.Merge
- MetaBlockAlreadyExists - Exception in org.apache.accumulo.core.file.rfile.bcfile
-
Exception - Meta Block with the same name already exists.
- MetaBlockDoesNotExist - Exception in org.apache.accumulo.core.file.rfile.bcfile
-
Exception - No such Meta Block with the given name.
- metaCache - Variable in class org.apache.accumulo.core.client.impl.TabletLocatorImpl
- METADATA - org.apache.accumulo.core.client.impl.TabletType
- MetadataLocationObtainer - Class in org.apache.accumulo.core.metadata
- MetadataLocationObtainer() - Constructor for class org.apache.accumulo.core.metadata.MetadataLocationObtainer
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticate_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.authenticateUser_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.bulkImportFiles_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeAuthorizations_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.changeLocalUserPassword_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkClass_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkNamespaceClass_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.checkTableClass_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.createLocalUser_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.dropLocalUser_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getConfiguration_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getDiskUsage_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getInstanceId_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getNamespaceConfiguration_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getRootTabletLocation_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getTableConfiguration_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getUserAuthorizations_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.getZooKeepers_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantNamespacePermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantSystemPermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.grantTablePermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasNamespacePermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasSystemPermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.hasTablePermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.isActive_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.listLocalUsers_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.ping_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeNamespacePermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeSystemPermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ClientService.revokeTablePermission_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.TDiskUsage
- metaDataMap - Static variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftSecurityException
- metaDataMap - Static variable in exception org.apache.accumulo.core.client.impl.thrift.ThriftTableOperationException
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.fails_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.success_result
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_args
- metaDataMap - Static variable in class org.apache.accumulo.core.client.impl.thrift.ThriftTest.throwsError_result
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.InitialMultiScan
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.InitialScan
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.IterInfo
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.MapFileInfo
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.MultiScanResult
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.ScanResult
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TCMResult
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TColumn
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TCondition
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TConditionalMutation
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TConditionalSession
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TConstraintViolationSummary
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TKey
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TKeyExtent
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TKeyValue
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TMutation
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.TRange
- metaDataMap - Static variable in class org.apache.accumulo.core.data.thrift.UpdateErrors
- metaDataMap - Static variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
- metaDataMap - Static variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
- metaDataMap - Static variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
- metaDataMap - Static variable in class org.apache.accumulo.core.gc.thrift.GCStatus
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.BulkImportStatus
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.Compacting
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.DeadServer
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_args
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.beginFateOperation_result
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_args
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.executeFateOperation_result
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_args
- metaDataMap - Static variable in class org.apache.accumulo.core.master.thrift.FateService.finishFateOperation_result
- metaDataMap - Static variable in class org.apache.accumulo.core.master.t