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

A

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

B

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

C

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

D

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

E

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

F

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

G

gather(ExecutorService) - Method in class org.apache.accumulo.core.summary.Gatherer
 
Gatherer - Class in org.apache.accumulo.core.summary
This class implements using multiple tservers to gather summaries.
Gatherer(ClientContext, TSummaryRequest, AccumuloConfiguration, CryptoService) - Constructor for class org.apache.accumulo.core.summary.Gatherer
 
Gatherer.FileSystemResolver - Interface in org.apache.accumulo.core.summary
 
Gatherer.RowRange - Class in org.apache.accumulo.core.summary
 
GC - org.apache.accumulo.core.lock.ServiceLockData.ThriftService
 
GC - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
GC_CANDIDATE_BATCH_SIZE - org.apache.accumulo.core.conf.Property
 
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_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_SAFEMODE - 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, long) - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
GcCycleStats(GcCycleStats) - Constructor for class org.apache.accumulo.core.gc.thrift.GcCycleStats
Performs a deep copy on other.
GcCycleStats._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService
 
GCMonitorService.AsyncClient - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncClient.Factory - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncClient.getStatus_call - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncIface - Interface in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncProcessor<I extends GCMonitorService.AsyncIface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.AsyncProcessor.getStatus<I extends GCMonitorService.AsyncIface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Client - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Client.Factory - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.getStatus_args - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.getStatus_args._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService.getStatus_result - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.getStatus_result._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GCMonitorService.Iface - Interface in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Processor<I extends GCMonitorService.Iface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorService.Processor.getStatus<I extends GCMonitorService.Iface> - Class in org.apache.accumulo.core.gc.thrift
 
GCMonitorServiceThriftClient - Class in org.apache.accumulo.core.rpc.clients
 
GCStatus - Class in org.apache.accumulo.core.gc.thrift
 
GCStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
 
GCStatus(GcCycleStats, GcCycleStats, GcCycleStats, GcCycleStats) - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
 
GCStatus(GCStatus) - Constructor for class org.apache.accumulo.core.gc.thrift.GCStatus
Performs a deep copy on other.
GCStatus._Fields - Enum in org.apache.accumulo.core.gc.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GENERAL_ARBITRARY_PROP_PREFIX - org.apache.accumulo.core.conf.Property
 
GENERAL_CONTEXT_CLASSLOADER_FACTORY - 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_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_LOW_MEM_DETECTOR_INTERVAL - org.apache.accumulo.core.conf.Property
 
GENERAL_LOW_MEM_DETECTOR_THRESHOLD - org.apache.accumulo.core.conf.Property
 
GENERAL_LOW_MEM_MAJC_PROTECTION - org.apache.accumulo.core.conf.Property
 
GENERAL_LOW_MEM_MINC_PROTECTION - org.apache.accumulo.core.conf.Property
 
GENERAL_LOW_MEM_SCAN_PROTECTION - 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_MICROMETER_ENABLED - org.apache.accumulo.core.conf.Property
 
GENERAL_MICROMETER_FACTORY - org.apache.accumulo.core.conf.Property
 
GENERAL_MICROMETER_JVM_METRICS_ENABLED - org.apache.accumulo.core.conf.Property
 
GENERAL_OPENTELEMETRY_ENABLED - org.apache.accumulo.core.conf.Property
 
GENERAL_PREFIX - org.apache.accumulo.core.conf.Property
 
GENERAL_PROCESS_BIND_ADDRESS - 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.conf.Property
 
GENERAL_SERVICE_NAME_PROP - Static variable in class org.apache.accumulo.core.spi.crypto.GenericCryptoServiceFactory
 
GENERAL_THREADPOOL_SIZE - org.apache.accumulo.core.conf.Property
 
GENERAL_VOLUME_CHOOSER - org.apache.accumulo.core.conf.Property
 
generate(UUID) - Static method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionId
 
GENERATED_TABLET_DIRECTORY_PREFIX - Static variable in class org.apache.accumulo.core.Constants
 
generateInitialTableProperties(boolean) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
Generate the initial (default) properties for a table
generateKey(SecureRandom, int) - Static method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
GenerateSplits - Class in org.apache.accumulo.core.file.rfile
 
GenerateSplits() - Constructor for class org.apache.accumulo.core.file.rfile.GenerateSplits
 
GenericCryptoServiceFactory - Class in org.apache.accumulo.core.spi.crypto
Factory that will load a crypto service configured, first checking GenericCryptoServiceFactory.GENERAL_SERVICE_NAME_PROP and then GenericCryptoServiceFactory.TABLE_SERVICE_NAME_PROP.
GenericCryptoServiceFactory() - Constructor for class org.apache.accumulo.core.spi.crypto.GenericCryptoServiceFactory
 
get() - Method in class org.apache.accumulo.core.data.Value
Gets the byte data of this value.
get() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlockQueue
Get a sorted List of all elements in this queue, in descending order.
get() - Method in class org.apache.accumulo.core.util.CancelFlagFuture
 
get() - Method in class org.apache.accumulo.core.util.format.DateFormatSupplier
Always sets the TimeZone, which is a fast operation
get(int) - Method in class org.apache.accumulo.core.util.PreAllocatedArray
Get the item stored at the specified index.
get(long, TimeUnit) - Method in class org.apache.accumulo.core.util.CancelFlagFuture
 
get(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
get(String) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
 
get(String) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
get(String) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property value from this configuration.
get(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Gets data at the given path.
get(String) - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
 
get(String) - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
 
get(String) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
get(String, ZooCache.ZcStat) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Gets data at the given path, filling status information into the given Stat object.
get(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
get(KT) - Method in class org.apache.accumulo.core.util.MapCounter
 
get(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property value from this configuration.
get(Property) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
get(Property) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
get(Property) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
get(Path) - Method in interface org.apache.accumulo.core.summary.Gatherer.FileSystemResolver
 
GET_SUMMARIES - org.apache.accumulo.core.security.TablePermission
 
getAcceptableFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getACL(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Retrieve the ACL list that was on the node
getActiveCompaction(HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
getActiveCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getActiveCompactions
 
getActiveCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getActiveCompactions
 
getActiveCompactions() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveCompactions
 
getActiveCompactions() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveCompactions
 
getActiveCompactions() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List all internal and external compactions running in Accumulo.
getActiveCompactions() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getActiveCompactions(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the active compaction running on a tablet server.
getActiveCompactions(String) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
getActiveCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.Iface
 
getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
getActiveCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncIface
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
getActiveCompactions(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
getActiveCompactions_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getActiveCompactions_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
getActiveCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getActiveCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
getActiveCompactions_args(CompactorService.getActiveCompactions_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
Performs a deep copy on other.
getActiveCompactions_args(TabletServerClientService.getActiveCompactions_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
Performs a deep copy on other.
getActiveCompactions_call(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getActiveCompactions_call
 
getActiveCompactions_call(TInfo, TCredentials, AsyncMethodCallback<List<ActiveCompaction>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getActiveCompactions_call
 
getActiveCompactions_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getActiveCompactions_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
getActiveCompactions_result(List<ActiveCompaction>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getActiveCompactions_result(List<ActiveCompaction>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
getActiveCompactions_result(CompactorService.getActiveCompactions_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
Performs a deep copy on other.
getActiveCompactions_result(TabletServerClientService.getActiveCompactions_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
Performs a deep copy on other.
getActiveLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveLogs
 
getActiveLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveLogs
 
getActiveLogs(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
getActiveLogs(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
getActiveLogs(TInfo, TCredentials, AsyncMethodCallback<List<String>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
getActiveLogs(TInfo, TCredentials, AsyncMethodCallback<List<String>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
getActiveLogs_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
getActiveLogs_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
getActiveLogs_args(TabletServerClientService.getActiveLogs_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
Performs a deep copy on other.
getActiveLogs_call(TInfo, TCredentials, AsyncMethodCallback<List<String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getActiveLogs_call
 
getActiveLogs_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
getActiveLogs_result(List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
getActiveLogs_result(TabletServerClientService.getActiveLogs_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
Performs a deep copy on other.
getActiveScans() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.getActiveScans
 
getActiveScans() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.getActiveScans
 
getActiveScans(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the active scans on a tablet server.
getActiveScans(String) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getActiveScans(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
getActiveScans(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Iface
 
getActiveScans(TInfo, TCredentials, AsyncMethodCallback<List<ActiveScan>>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient
 
getActiveScans(TInfo, TCredentials, AsyncMethodCallback<List<ActiveScan>>) - Method in interface org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncIface
 
getActiveScans_args() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
getActiveScans_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
getActiveScans_args(TabletScanClientService.getActiveScans_args) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
Performs a deep copy on other.
getActiveScans_call(TInfo, TCredentials, AsyncMethodCallback<List<ActiveScan>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.getActiveScans_call
 
getActiveScans_result() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
getActiveScans_result(List<ActiveScan>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
getActiveScans_result(TabletScanClientService.getActiveScans_result) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
Performs a deep copy on other.
getActiveTservers() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getActiveTservers
 
getActiveTservers() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getActiveTservers
 
getActiveTservers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
getActiveTservers(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
getActiveTservers(TInfo, TCredentials, AsyncMethodCallback<List<String>>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
getActiveTservers(TInfo, TCredentials, AsyncMethodCallback<List<String>>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
getActiveTservers_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getActiveTservers_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getActiveTservers_args(ManagerClientService.getActiveTservers_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
Performs a deep copy on other.
getActiveTservers_call(TInfo, TCredentials, AsyncMethodCallback<List<String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getActiveTservers_call
 
getActiveTservers_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getActiveTservers_result(List<String>, ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getActiveTservers_result(ManagerClientService.getActiveTservers_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
Performs a deep copy on other.
getAddress() - Method in interface org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost
 
getAddress() - Method in class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptor
 
getAddress() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerInfo
 
getAddress(ServiceLockData.ThriftService) - Method in class org.apache.accumulo.core.lock.ServiceLockData
 
getAddressCacheNegativeTtl(UnknownHostException) - Static method in class org.apache.accumulo.core.util.AddressUtil
Fetch the security value that determines how long DNS failures are cached.
getAddressString(ServiceLockData.ThriftService) - Method in class org.apache.accumulo.core.lock.ServiceLockData
 
getAge() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getAge() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getAge() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getAge() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getAge() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getAll() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getAllCryptoProperties() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getAllPropertiesWithPrefix(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets all properties under the given prefix in this configuration.
getAllPropertiesWithPrefixStripped(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getAmple() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getAnonymousSession(String, int) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooSession
 
getAnyTransport(List<ThriftTransportKey>, boolean) - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportPool
 
getArguments() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getArgumentsIterator() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getArgumentsSize() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getAsBytes(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.BYTES or PropertyType.MEMORY, interpreting the value properly.
getAssignment(SortedMap<TabletServerId, TServerStatus>, TabletServerId) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
getAssignments(TabletBalancer.AssignmentParameters) - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer
Assign tablets to tablet servers.
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.Factory
 
getAsyncClient(TNonblockingTransport) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.Factory
 
getAttempts(TabletId) - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.SelectorParameters
 
getAuthenticatedSession(String, int, String, byte[]) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooSession
 
getAuthenticationToken() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getAuthenticationToken() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getAuthenticationToken() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getAuthenticationToken(Properties) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
getAuthorizationFailures() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getAuthorizationFailuresSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getAuthorizations() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getAuthorizations() - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the authorizations that have been set on the scanner
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReader
 
getAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizations() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Return the Scan Authorizations used in this Iterator.
getAuthorizations() - Method in class org.apache.accumulo.core.security.Authorizations
Gets the authorizations in sorted order.
getAuthorizations() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getAuthorizations() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getAuthorizationsArray() - Method in class org.apache.accumulo.core.security.Authorizations
Returns a serialized form of these authorizations.
getAuthorizationsBB() - Method in class org.apache.accumulo.core.security.Authorizations
Gets the authorizations in sorted order.
getAuthorizationsContainer() - Method in interface org.apache.accumulo.core.data.constraints.Constraint.Environment
Gets the authorizations in the environment.
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getAuthorizationsIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getAuthorizationsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getAvailableFiles() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getBackingArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
getBackingArray() - Method in class org.apache.accumulo.core.data.ByteSequence
Gets the backing byte array for this sequence.
getBadTServers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBadTServersSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBalancerForTable(TableId) - Method in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
getBasePath() - Method in interface org.apache.accumulo.core.volume.Volume
The base path which Accumulo will use within the given FileSystem
getBasePath() - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
getBatch() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getBatchFromServer(ClientContext, Range, KeyExtent, String, SortedMap<Key, Value>, SortedSet<Column>, List<IterInfo>, Map<String, Map<String, String>>, int, Authorizations, long, String) - Static method in class org.apache.accumulo.core.clientImpl.ThriftScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getBatchSize() - Method in interface org.apache.accumulo.core.client.Scanner
Returns the batch size (number of Key/Value pairs) that will be fetched at a time from a tablet server.
getBatchSize() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
getBatchSize() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getBatchSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getBatchSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getBatchTimeout(TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the timeout to fill a batch in the given TimeUnit.
getBatchTimeout(TimeUnit) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getBatchTimeOut() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getBatchTimeOut() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getBatchWriter(String) - Method in interface org.apache.accumulo.core.client.MultiTableBatchWriter
Returns a BatchWriter for a particular table.
getBatchWriter(String) - Method in class org.apache.accumulo.core.clientImpl.MultiTableBatchWriterImpl
 
getBatchWriterConfig() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getBehavior(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator
 
getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the buffer of the block with the specified name.
getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getBlock(String) - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Fetch block from cache.
getBlock(String, BlockCache.Loader) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.SynchronousLoadingBlockCache
 
getBlock(String, BlockCache.Loader) - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getBlock(String, BlockCache.Loader) - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getBlock(String, BlockCache.Loader) - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
This method allows a cache to prevent concurrent loads of the same block.
getBlockCache(CacheType) - Method in class org.apache.accumulo.core.spi.cache.BlockCacheManager
Get the block cache of the given type
getBlockCount() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Get the number of data blocks.
getBlockNoStats(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getBlockNoStats(String) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.SynchronousLoadingBlockCache
Get a block from the cache without changing any stats the cache is keeping.
getBlockSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getBlockSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getBlockSize() - Method in interface org.apache.accumulo.core.spi.cache.BlockCacheManager.Configuration
Before Accumulo's cache implementation was configurable, its built in cache had a configurable block size.
getBoolean(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getBoolean(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.BOOLEAN, interpreting the value properly (using Boolean.parseBoolean()).
getBounds() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
getBuffer() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getBuffer() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getBuffer() - Method in interface org.apache.accumulo.core.spi.cache.CacheEntry
 
getBufferPosition() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getBufferSizeProperty() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getBufferSizeProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getBulkImports() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBulkImports() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getBulkImportsIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBulkImportsIterator() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getBulkImportsSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getBulkImportsSize() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getBulkLoadTid(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
getBulkLoadTid(Value) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
getBulks() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getBulkWorkingFiles() - Static method in class org.apache.accumulo.core.file.FileOperations
 
getBusyTimeout() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelections
 
getBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
getBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
getBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getByteBuffer(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
getBytes() - Method in class org.apache.accumulo.core.dataImpl.ComparableBytes
Gets the wrapped bytes in this object.
getBytes(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getBytes(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
getBytesRead() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
getBytesRead() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
getBytesRemainingInBuffer() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getBytesWritten() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
getBytesWritten() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
getCachePropertyBase(Property) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getCacheProvider() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getCallbackHandler() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The SASL callback handler for this mechanism, may be null.
getCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getCandidates() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getCf() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getCfg() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getChildren() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getChildren(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Gets the children of the given node.
getChildren(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getChildren(String, Watcher) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getChooserScope() - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment
 
getClassInstance(String, String, Class<T>) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Loads a class in the given classloader context.
getClassInstance(String, String, Class<T>, T) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Loads a class in the given classloader context, suppressing any exceptions, and optionally providing a default instance to use.
getClassLoader() - Static method in class org.apache.accumulo.core.classloader.ClassLoaderUtil
 
getClassLoader(String) - Static method in class org.apache.accumulo.core.classloader.ClassLoaderUtil
 
getClassLoader(String) - Method in class org.apache.accumulo.core.classloader.URLContextClassLoaderFactory
 
getClassLoader(String) - Method in interface org.apache.accumulo.core.spi.common.ContextClassLoaderFactory
Get the class loader for the given context.
getClassLoaderContext() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Returns the name of the current classloader context set on this scanner
getClassLoaderContext() - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the name of the current classloader context set on this scanner
getClassLoaderContext() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getClassLoaderContext() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getClassname() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getClassName() - Method in class org.apache.accumulo.core.client.admin.PluginConfig
 
getClassName() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
 
getClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getClassName() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
getClassName() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
getClassName() - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
getClient() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getClient() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getClient() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getClient(ThriftClientTypes<T>, HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a Thrift client using the given factory with a pooled transport (if available), the address and client context.
getClient(ThriftClientTypes<T>, HostAndPort, ClientContext, long) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a Thrift client using the given factory with a pooled transport (if available) using the address, client context and timeout
getClient(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client.Factory
 
getClient(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client.Factory
 
getClientConfigFile() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getClientFactory() - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getClientInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheManagerFactory
Get the BlockCacheFactory specified by the property 'tserver.cache.factory.class'
getClientNoTimeout(ThriftClientTypes<T>, HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Create a Thrift client using the given factory with a pooled transport (if available), the address, and client context with no timeout.
getClientProps() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getClientProtocol() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getClientReservation() - Static method in class org.apache.accumulo.core.singletons.SingletonManager
This method should be called when creating Accumulo clients using the public API.
getClientScanIterators() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
 
getClientSslParams() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve SSL/TLS configuration to initiate an RPC connection to a server
getClientString() - Method in class org.apache.accumulo.core.rpc.TBufferedSocket
 
getClientThreadPools(Thread.UncaughtExceptionHandler) - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
 
getClientTimeoutInMillis() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve the universal RPC client timeout from the configuration
getCloned() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getCmid() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
getCode() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
getCode() - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
getCode(String) - Static method in class org.apache.accumulo.core.metadata.schema.SortSkew
Creates a left justified hex string for the path hashcode of a deterministic length, therefore if necessary it is right padded with zeros
getCode(TimeType) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getCodecClassName() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getCodecClassName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getCodecClassNameProperty() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getCodecClassNameProperty() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getColFamily() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getColQualifier() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getColumnFamilies() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getColumnFamily() - Method in class org.apache.accumulo.core.client.IteratorSetting.Column
 
getColumnFamily() - Method in class org.apache.accumulo.core.data.Column
Gets the column family.
getColumnFamily() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Gets the column family for this update.
getColumnFamily() - Method in class org.apache.accumulo.core.data.Key
Gets the column family as a Text object.
getColumnFamily() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
getColumnFamily() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getColumnFamily() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
getColumnFamily(Text) - Method in class org.apache.accumulo.core.data.Key
Writes the column family into the given Text.
getColumnFamilyData() - Method in class org.apache.accumulo.core.data.Key
Returns the column family as a byte sequence.
getColumnQualifier() - Method in class org.apache.accumulo.core.client.IteratorSetting.Column
 
getColumnQualifier() - Method in class org.apache.accumulo.core.data.Column
Gets the column qualifier.
getColumnQualifier() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Gets the column qualifier for this update.
getColumnQualifier() - Method in class org.apache.accumulo.core.data.Key
Gets the column qualifier as a Text object.
getColumnQualifier() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
getColumnQualifier() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getColumnQualifier() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
getColumnQualifier(Text) - Method in class org.apache.accumulo.core.data.Key
Writes the column qualifier into the given Text.
getColumnQualifierData() - Method in class org.apache.accumulo.core.data.Key
Returns the column qualifier as a byte sequence.
getColumns() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getColumns() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getColumns() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getColumns() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getColumns() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getColumnsIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getColumnsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getColumnVisibility() - Method in class org.apache.accumulo.core.data.Column
Gets the column visibility.
getColumnVisibility() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Gets the column visibility for this update.
getColumnVisibility() - Method in class org.apache.accumulo.core.data.Key
Gets the column visibility as a Text object.
getColumnVisibility() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
getColumnVisibility(Text) - Method in class org.apache.accumulo.core.data.Key
Writes the column visibility into the given Text.
getColumnVisibilityData() - Method in class org.apache.accumulo.core.data.Key
Returns the column visibility as a byte sequence.
getColumnVisibilityParsed() - Method in class org.apache.accumulo.core.data.Key
Gets the column visibility.
getColVisibility() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getCommonTags() - Static method in class org.apache.accumulo.core.metrics.MetricsUtil
 
getCompactId() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getCompactionExecutorId() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getCompactionId() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getCompactionIdsRunningOnCompactors(ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
getCompactionJob() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompactionJob
 
getCompactionJob() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompactionJob
 
getCompactionJob(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
getCompactionJob(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
getCompactionJob(TInfo, TCredentials, String, String, String, AsyncMethodCallback<TExternalCompactionJob>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
getCompactionJob(TInfo, TCredentials, String, String, String, AsyncMethodCallback<TExternalCompactionJob>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
getCompactionJob_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getCompactionJob_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getCompactionJob_args(CompactionCoordinatorService.getCompactionJob_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
Performs a deep copy on other.
getCompactionJob_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback<TExternalCompactionJob>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompactionJob_call
 
getCompactionJob_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
getCompactionJob_result(CompactionCoordinatorService.getCompactionJob_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
Performs a deep copy on other.
getCompactionJob_result(TExternalCompactionJob) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
getCompactionKind() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.DispatchParameters
 
getCompactionQueueInfo() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getCompactionQueueInfo
 
getCompactionQueueInfo() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getCompactionQueueInfo
 
getCompactionQueueInfo(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
getCompactionQueueInfo(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
getCompactionQueueInfo(TInfo, TCredentials, AsyncMethodCallback<List<TCompactionQueueSummary>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
getCompactionQueueInfo(TInfo, TCredentials, AsyncMethodCallback<List<TCompactionQueueSummary>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
getCompactionQueueInfo_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
getCompactionQueueInfo_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
getCompactionQueueInfo_args(TabletServerClientService.getCompactionQueueInfo_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
Performs a deep copy on other.
getCompactionQueueInfo_call(TInfo, TCredentials, AsyncMethodCallback<List<TCompactionQueueSummary>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getCompactionQueueInfo_call
 
getCompactionQueueInfo_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
getCompactionQueueInfo_result(List<TCompactionQueueSummary>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
getCompactionQueueInfo_result(TabletServerClientService.getCompactionQueueInfo_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
Performs a deep copy on other.
getCompactions() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
getCompactionServices() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.DispatchParameters
 
getCompactionsRunningOnCompactors(ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
This method returns information from the Compactor about the job that is currently running.
getCompactionsSize() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
getCompactor() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getCompactor() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getCompactor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
getCompactorAddress() - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
getCompactorAddrs(ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
 
getCompactorId() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getCompactTmpName() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getCompletedCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions
 
getCompletedCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompletedCompactions
 
getCompletedCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
getCompletedCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
getCompletedCompactions(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
getCompletedCompactions(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
getCompletedCompactions_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getCompletedCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getCompletedCompactions_args(CompactionCoordinatorService.getCompletedCompactions_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
Performs a deep copy on other.
getCompletedCompactions_call(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompletedCompactions_call
 
getCompletedCompactions_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
getCompletedCompactions_result(CompactionCoordinatorService.getCompletedCompactions_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
Performs a deep copy on other.
getCompletedCompactions_result(TExternalCompactionList) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
Get the compressed size of the block in progress.
getCompressedSize() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getCompression() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getCompressionAlgorithmByName(String) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Compression
 
getCompressor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
getCompressorType() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
getConditionalWriterConfig() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getConditions() - Method in class org.apache.accumulo.core.data.ConditionalMutation
 
getConditions() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getConditionsIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getConditionsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getConfig() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getConfig() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor
 
getConfigId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getConfiguration
 
getConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getConfiguration
 
getConfiguration() - Method in interface org.apache.accumulo.core.client.PluginEnvironment
 
getConfiguration() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve the configuration used to construct this context
getConfiguration() - Method in class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
getConfiguration() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getConfiguration() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getConfiguration() - Method in interface org.apache.accumulo.core.spi.common.ContextClassLoaderEnvironment
Get the service environment configuration
getConfiguration() - Method in interface org.apache.accumulo.core.spi.common.ServiceEnvironment
 
getConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Gets properties of a namespace, which are inherited by tables in this namespace.
getConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets properties of a table.
getConfiguration(String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
getConfiguration(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getConfiguration(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getConfiguration(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getConfiguration(TableId) - Method in interface org.apache.accumulo.core.client.PluginEnvironment
 
getConfiguration(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
getConfiguration(TableId) - Method in interface org.apache.accumulo.core.spi.common.ServiceEnvironment
 
getConfiguration_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getConfiguration_args(ClientService.getConfiguration_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
Performs a deep copy on other.
getConfiguration_args(TInfo, TCredentials, ConfigurationType) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getConfiguration_call(TInfo, TCredentials, ConfigurationType, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getConfiguration_call
 
getConfiguration_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getConfiguration_result(Map<String, String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getConfiguration_result(ClientService.getConfiguration_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
Performs a deep copy on other.
getConfigurer() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getConnection(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.FateThriftClient
 
getConnection(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.ManagerThriftClient
 
getConnection(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getConnectionWithRetry(ClientContext) - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getConsistencyLevel() - Method in interface org.apache.accumulo.core.client.ScannerBase
Get the configured consistency level
getConsistencyLevel() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getConstrainClass() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getConstrainClass() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
getConstraintViolationSummaries() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getCount() - Method in class org.apache.accumulo.core.iteratorsImpl.system.CountingIterator
 
getCount() - Method in class org.apache.accumulo.core.spi.crypto.PerTableCryptoServiceFactory
 
getCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getCount(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.COUNT, interpreting the value properly (as an integer).
getCounters() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getCq() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getCreationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getCreationTime() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
Returns the first time a tablet knew about a scan over its portion of data.
getCredentialProviders() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve the credentials used to construct this context
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getCredentials() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
getCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
getCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
getCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
getCryptoEnv(CryptoEnvironment.Scope, TableId, DataInputStream) - Static method in class org.apache.accumulo.core.crypto.CryptoUtils
 
getCryptoService() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getCryptoService() - Method in class org.apache.accumulo.core.file.rfile.bcfile.PrintBCInfo
 
getCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getCurrentMaxThreads() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
Re-reads the max threads from the configuration that created this class
getCurrentServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getCurrentSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the current size of this cache.
getCustom() - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Users can set arbitrary custom properties in Accumulo using the prefix general.custom..
getCustom() - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getCustom(String) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
This method appends the prefix general.custom and gets the property.
getCustom(String) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getCv() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getCve() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
getDanglingHeldLocks() - Method in class org.apache.accumulo.core.fate.AdminUtil.FateStatus
Get locks that are held by non existent FATE transactions.
getDanglingWaitingLocks() - Method in class org.apache.accumulo.core.fate.AdminUtil.FateStatus
Get locks that are waiting to be acquired by non existent FATE transactions.
getData() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getData(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getData(String, Stat) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getData(String, Watcher) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getData(String, Watcher, Stat) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getDataBlock(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
It is intended that once the BlockRead object is returned to the caller, that the caller will read the entire block and then call close on the BlockRead class.
getDataBlock(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Stream access to a Data Block.
getDataBlock(long, long, long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
getDataBlock(long, long, long) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
getDataBlockRawSize(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
getDataCache() - Method in class org.apache.accumulo.core.file.blockfile.impl.BasicCacheProvider
 
getDataCache() - Method in interface org.apache.accumulo.core.file.blockfile.impl.CacheProvider
 
getDataCache() - Method in class org.apache.accumulo.core.file.blockfile.impl.ScanCacheProvider
 
getDataCacheHits() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getDataCacheHits() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getDataCacheHits() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getDataCacheRequest() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getDataCacheRequests() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getDataCacheRequests() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getDataCacheUsage() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch
 
getDateFormatSupplier() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
 
getDeadTabletServers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getDeadTabletServersIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getDeadTabletServersSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getDecompressor() - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
getDecompressorType() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
getDecrypter(Key) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule
 
getDecrypter(Key) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule
 
getDecryptionParameters() - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule.AESCBCFileEncrypter
 
getDecryptionParameters() - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule.AESGCMFileEncrypter
 
getDecryptionParameters() - Method in interface org.apache.accumulo.core.spi.crypto.FileEncrypter
Get all the parameters required for decryption.
getDecryptionParameters() - Method in class org.apache.accumulo.core.spi.crypto.NoFileEncrypter
 
getDecryptionParams() - Method in class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
 
getDecryptionParams() - Method in interface org.apache.accumulo.core.spi.crypto.CryptoEnvironment
If decrypting files, get the params read from the file.
getDeepCopyDataSource(IteratorEnvironment) - Method in interface org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator.DataSource
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getDefaultBufferSize() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getDefaultBufferSize() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getDefaultExtension() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
getDefaultFormatter(Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
 
getDefaultRealm() - Static method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
getDefaultValue() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getDefaultValue() - Method in enum org.apache.accumulo.core.conf.Property
Gets the default value for this property.
getDelay() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelections
 
getDelegationToken() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getDelegationToken
 
getDelegationToken() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getDelegationToken
 
getDelegationToken(DelegationTokenConfig) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Obtain a DelegationToken for use when Kerberos credentials cannot be used (e.g.
getDelegationToken(DelegationTokenConfig) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback<TDelegationToken>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback<TDelegationToken>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
getDelegationToken_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getDelegationToken_args(TInfo, TCredentials, TDelegationTokenConfig) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getDelegationToken_args(ManagerClientService.getDelegationToken_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
Performs a deep copy on other.
getDelegationToken_call(TInfo, TCredentials, TDelegationTokenConfig, AsyncMethodCallback<TDelegationToken>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getDelegationToken_call
 
getDelegationToken_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getDelegationToken_result(ManagerClientService.getDelegationToken_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
Performs a deep copy on other.
getDelegationToken_result(TDelegationToken, ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getDeleted() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getDeletedFiles() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getDeletesIgnored() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getDependencies() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache.Loader
The cache blocks that this loader depends on.
getDepth() - Method in enum org.apache.accumulo.core.data.PartialKey
Gets the depth of this partial key.
getDerived(Function<PluginEnvironment.Configuration, T>) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Returns a derived value from this Configuration.
getDerived(Function<PluginEnvironment.Configuration, T>) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getDescription() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
getDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
getDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getDescription() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getDescription() - Method in enum org.apache.accumulo.core.conf.Property
Gets the description of this property.
getDescription() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getDescription() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
getDesiredRate() - Method in interface org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory.RateProvider
Calculate the current rate for the RateLimiter.
getDestinations() - Method in class org.apache.accumulo.core.data.LoadPlan
 
getDir() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
getDirName() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getDiskUsage() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
getDiskUsage() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getDiskUsage
 
getDiskUsage(Set<String>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets the number of bytes being used by the files for a set of tables.
getDiskUsage(Set<String>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getDiskUsage(Set<String>, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getDiskUsage(Set<String>, TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getDiskUsage(Set<String>, TCredentials, AsyncMethodCallback<List<TDiskUsage>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getDiskUsage(Set<String>, TCredentials, AsyncMethodCallback<List<TDiskUsage>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getDiskUsage_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getDiskUsage_args(Set<String>, TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getDiskUsage_args(ClientService.getDiskUsage_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
Performs a deep copy on other.
getDiskUsage_call(Set<String>, TCredentials, AsyncMethodCallback<List<TDiskUsage>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getDiskUsage_call
 
getDiskUsage_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getDiskUsage_result(List<TDiskUsage>, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getDiskUsage_result(ClientService.getDiskUsage_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
Performs a deep copy on other.
getDocID(Key) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
getDocID(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getDuplicateReads() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getDurability() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getDurability() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getDurability() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getDurability() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
getDurability() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
getEarlierEntries(long) - Method in interface org.apache.accumulo.core.fate.zookeeper.DistributedReadWriteLock.QueueLock
 
getEarlierEntries(long) - Method in class org.apache.accumulo.core.fate.zookeeper.FateLock
 
getElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getEmitted() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticateUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkTableClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.createLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getInstanceId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getSystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedSystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.isActive
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.ping
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticateUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeLocalUserPassword
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkNamespaceClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkTableClass
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.createLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.dropLocalUser
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getDiskUsage
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getInstanceId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getRootTabletLocation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getSystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableConfiguration
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getUserAuthorizations
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedSystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getZooKeepers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.isActive
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.listLocalUsers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.ping
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeNamespacePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeSystemPermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeTablePermission
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.fails
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.success
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.throwsError
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.fails
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.success
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.throwsError
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.cancel
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionCompleted
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionFailed
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompactionJob
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getRunningCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.updateCompactionStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.cancel
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionCompleted
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionFailed
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompactionJob
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompletedCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getRunningCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.updateCompactionStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.cancel
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompaction
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompactionId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.cancel
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompaction
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompactionId
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.beginFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.cancelFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.executeFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.finishFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.waitForFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.beginFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.cancelFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.executeFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.finishFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.waitForFateOperation
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getActiveTservers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getDelegationToken
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getManagerStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.initiateFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifySystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportSplitExtent
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportTabletStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setManagerGoalState
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdown
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdownTabletServer
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForBalance
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getActiveTservers
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getDelegationToken
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getManagerStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.initiateFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyNamespaceProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifySystemProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyTableProperties
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportSplitExtent
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportTabletStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setManagerGoalState
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setNamespaceProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setSystemProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setTableProperty
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdown
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdownTabletServer
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForBalance
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForFlush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.chop
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.flushTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.loadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.splitTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.unloadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.chop
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.flushTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.loadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.splitTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.unloadTablet
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.applyUpdates
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.closeConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.closeUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.conditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.invalidateConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.loadFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.update
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.applyUpdates
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.closeConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.closeUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.conditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.invalidateConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.loadFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startConditionalUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startUpdate
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.update
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.closeMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.closeScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.continueMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.continueScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.getActiveScans
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.closeMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.closeScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.continueMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.continueScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.getActiveScans
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startMultiScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startScan
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compact
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compactionJobFailed
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compactionJobFinished
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.contiuneGetSummaries
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.fastHalt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.flush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getCompactionQueueInfo
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getHistoricalStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletServerStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.halt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.removeLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.reserveCompactionJob
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummaries
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesForPartition
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesFromFiles
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compact
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compactionJobFailed
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compactionJobFinished
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.contiuneGetSummaries
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.fastHalt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.flush
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveCompactions
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getCompactionQueueInfo
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getHistoricalStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletServerStatus
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletStats
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.halt
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.removeLogs
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.reserveCompactionJob
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummaries
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesForPartition
 
getEmptyArgsInstance() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesFromFiles
 
getEncodedEndRow() - Method in exception org.apache.accumulo.core.metadata.TabletLocationState.BadLocationStateException
 
getEncrypter() - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule
 
getEncrypter() - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESGCMCryptoModule
 
getEndKey() - Method in class org.apache.accumulo.core.data.Range
Gets the ending key, or null if the end is positive infinity.
getEndRow() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getEndRow() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Tablet
 
getEndRow() - Method in class org.apache.accumulo.core.data.LoadPlan.Destination
 
getEndRow() - Method in interface org.apache.accumulo.core.data.TabletId
 
getEndRow() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
getEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
getEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
getEndRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getEndRow() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getEndRow() - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment
The end row of the tablet for which a volume is being chosen.
getEndRow() - Method in class org.apache.accumulo.core.summary.Gatherer.RowRange
 
getEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
getEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
getEntries() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getEntries() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
getEntriesLeft() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
getEntriesRead() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getEntriesRead() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getEntriesRead() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
getEntriesToBeCompacted() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getEntriesWritten() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getEntriesWritten() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getEntriesWritten() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
getEnvironment() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InitParameters
 
getEnvironment() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InputParameters
 
getEnvironment() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.InitParameters
 
getEnvironment() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getEphemeralOwner() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache.ZcStat
 
getEquivalent(SystemPermission) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
 
getEquivalent(TablePermission) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
 
getErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getErrorServers() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getEstFileSize() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
getEstimatedEntries() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
getEstimatedEntries() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getEstimatedSize() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
getEstimatedSize() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getEstimatedSize() - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
getEstNumEntries() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
getEvictedCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getEvictedCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the number of blocks that have been evicted during the lifetime of this cache.
getEvictionCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getEvictionCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the number of eviction runs that have occurred
getEx() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
getException(long) - Method in class org.apache.accumulo.core.fate.Fate
 
getExecutionHints() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getExecutionHints() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.DispatchParameters
 
getExecutionHints() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getExecutionHints() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
 
getExecutionHints() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getExecutionHints() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getExecutionHintsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getExecutionHintsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getExecutor() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionJob
 
getExecutor() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
getExecutorManager() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.InitParameters
 
getExecutorManager() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getExecutorName() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch
 
getExpirationDate() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getExpirationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getExpirationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getExportedProps(FileSystem, Path) - Static method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getExpression() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Accessor for the underlying byte string.
getExtent() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocation
 
getExtent() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getExtent() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getExtent() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getExtent() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
getExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getExtent() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getExtent() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
getExtent() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getExternalCompactionFinalStates() - Method in interface org.apache.accumulo.core.metadata.schema.Ample
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
getExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getExternalCompactions() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getExternalExecutor(String) - Method in interface org.apache.accumulo.core.spi.compaction.ExecutorManager
 
getExternalName() - Method in class org.apache.accumulo.core.util.compaction.CompactionExecutorIdImpl
 
getExtra() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getFail() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getFailedExtents() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getFailedExtentsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getFailures() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFailuresSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFamily() - Method in class org.apache.accumulo.core.data.Condition
Gets the column family of this condition.
getFetchedColumns() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getFetchedColumns() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
This method returns what column were fetched by a scan.
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyValue._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.BulkImportStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.Compacting._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.DeadServer._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.RecoveryStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.DataFileInfo._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration._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.InputFile._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
getFieldName() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
getFieldValue(ClientService.authenticate_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
getFieldValue(ClientService.authenticate_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
getFieldValue(ClientService.authenticateUser_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
getFieldValue(ClientService.authenticateUser_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
getFieldValue(ClientService.changeAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getFieldValue(ClientService.changeAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
getFieldValue(ClientService.changeLocalUserPassword_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getFieldValue(ClientService.changeLocalUserPassword_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
getFieldValue(ClientService.checkClass_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getFieldValue(ClientService.checkClass_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
getFieldValue(ClientService.checkNamespaceClass_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getFieldValue(ClientService.checkNamespaceClass_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
getFieldValue(ClientService.checkTableClass_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getFieldValue(ClientService.checkTableClass_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
getFieldValue(ClientService.createLocalUser_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getFieldValue(ClientService.createLocalUser_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
getFieldValue(ClientService.dropLocalUser_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
getFieldValue(ClientService.dropLocalUser_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
getFieldValue(ClientService.getConfiguration_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getFieldValue(ClientService.getConfiguration_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getFieldValue(ClientService.getDiskUsage_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getFieldValue(ClientService.getDiskUsage_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getFieldValue(ClientService.getInstanceId_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
getFieldValue(ClientService.getInstanceId_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
getFieldValue(ClientService.getNamespaceConfiguration_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getFieldValue(ClientService.getNamespaceConfiguration_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getFieldValue(ClientService.getNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getFieldValue(ClientService.getNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getFieldValue(ClientService.getRootTabletLocation_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
getFieldValue(ClientService.getRootTabletLocation_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
getFieldValue(ClientService.getSystemProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getFieldValue(ClientService.getSystemProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getFieldValue(ClientService.getTableConfiguration_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getFieldValue(ClientService.getTableConfiguration_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getFieldValue(ClientService.getTableProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getFieldValue(ClientService.getTableProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getFieldValue(ClientService.getUserAuthorizations_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getFieldValue(ClientService.getUserAuthorizations_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getFieldValue(ClientService.getVersionedNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getFieldValue(ClientService.getVersionedNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getFieldValue(ClientService.getVersionedSystemProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
getFieldValue(ClientService.getVersionedSystemProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
getFieldValue(ClientService.getVersionedTableProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getFieldValue(ClientService.getVersionedTableProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getFieldValue(ClientService.getZooKeepers_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
getFieldValue(ClientService.getZooKeepers_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
getFieldValue(ClientService.grantNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getFieldValue(ClientService.grantNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
getFieldValue(ClientService.grantSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getFieldValue(ClientService.grantSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
getFieldValue(ClientService.grantTablePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getFieldValue(ClientService.grantTablePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
getFieldValue(ClientService.hasNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getFieldValue(ClientService.hasNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
getFieldValue(ClientService.hasSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getFieldValue(ClientService.hasSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
getFieldValue(ClientService.hasTablePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getFieldValue(ClientService.hasTablePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
getFieldValue(ClientService.isActive_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
getFieldValue(ClientService.isActive_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
getFieldValue(ClientService.listLocalUsers_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
getFieldValue(ClientService.listLocalUsers_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getFieldValue(ClientService.ping_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
getFieldValue(ClientService.ping_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
getFieldValue(ClientService.revokeNamespacePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getFieldValue(ClientService.revokeNamespacePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
getFieldValue(ClientService.revokeSystemPermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getFieldValue(ClientService.revokeSystemPermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
getFieldValue(ClientService.revokeTablePermission_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getFieldValue(ClientService.revokeTablePermission_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
getFieldValue(TDiskUsage._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getFieldValue(ThriftConcurrentModificationException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
getFieldValue(ThriftNotActiveServiceException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
getFieldValue(ThriftSecurityException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
getFieldValue(ThriftTableOperationException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getFieldValue(ThriftTest.fails_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
getFieldValue(ThriftTest.fails_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
getFieldValue(ThriftTest.success_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
getFieldValue(ThriftTest.success_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
getFieldValue(ThriftTest.throwsError_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
getFieldValue(ThriftTest.throwsError_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
getFieldValue(TInfo._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
getFieldValue(TVersionedProperties._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
getFieldValue(CompactionCoordinatorService.cancel_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
getFieldValue(CompactionCoordinatorService.cancel_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
getFieldValue(CompactionCoordinatorService.compactionCompleted_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getFieldValue(CompactionCoordinatorService.compactionCompleted_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
getFieldValue(CompactionCoordinatorService.compactionFailed_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getFieldValue(CompactionCoordinatorService.compactionFailed_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
getFieldValue(CompactionCoordinatorService.getCompactionJob_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getFieldValue(CompactionCoordinatorService.getCompactionJob_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
getFieldValue(CompactionCoordinatorService.getCompletedCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getFieldValue(CompactionCoordinatorService.getCompletedCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
getFieldValue(CompactionCoordinatorService.getRunningCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getFieldValue(CompactionCoordinatorService.getRunningCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
getFieldValue(CompactionCoordinatorService.updateCompactionStatus_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getFieldValue(CompactionCoordinatorService.updateCompactionStatus_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
getFieldValue(CompactorService.cancel_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
getFieldValue(CompactorService.cancel_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
getFieldValue(CompactorService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getFieldValue(CompactorService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getFieldValue(CompactorService.getRunningCompaction_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getFieldValue(CompactorService.getRunningCompaction_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getFieldValue(CompactorService.getRunningCompactionId_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getFieldValue(CompactorService.getRunningCompactionId_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getFieldValue(TCompactionStatusUpdate._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getFieldValue(TExternalCompaction._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getFieldValue(TExternalCompactionList._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
getFieldValue(UnknownCompactionIdException._Fields) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
getFieldValue(InitialMultiScan._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
getFieldValue(InitialScan._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
getFieldValue(IterInfo._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
getFieldValue(MultiScanResult._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFieldValue(ScanResult._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
getFieldValue(TCMResult._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
getFieldValue(TColumn._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
getFieldValue(TCondition._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getFieldValue(TConditionalMutation._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getFieldValue(TConditionalSession._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
getFieldValue(TConstraintViolationSummary._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
getFieldValue(TKey._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getFieldValue(TKeyExtent._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
getFieldValue(TKeyValue._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
getFieldValue(TMutation._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getFieldValue(TRange._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
getFieldValue(TRowRange._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
getFieldValue(TSummaries._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getFieldValue(TSummarizerConfiguration._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getFieldValue(TSummary._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getFieldValue(TSummaryRequest._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getFieldValue(UpdateErrors._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getFieldValue(GcCycleStats._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getFieldValue(GCMonitorService.getStatus_args._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getFieldValue(GCMonitorService.getStatus_result._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getFieldValue(GCStatus._Fields) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getFieldValue(BulkImportStatus._Fields) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
getFieldValue(Compacting._Fields) - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
getFieldValue(DeadServer._Fields) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
getFieldValue(FateService.beginFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
getFieldValue(FateService.beginFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
getFieldValue(FateService.cancelFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
getFieldValue(FateService.cancelFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
getFieldValue(FateService.executeFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getFieldValue(FateService.executeFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
getFieldValue(FateService.finishFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
getFieldValue(FateService.finishFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
getFieldValue(FateService.waitForFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
getFieldValue(FateService.waitForFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getFieldValue(ManagerClientService.getActiveTservers_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getFieldValue(ManagerClientService.getActiveTservers_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getFieldValue(ManagerClientService.getDelegationToken_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getFieldValue(ManagerClientService.getDelegationToken_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getFieldValue(ManagerClientService.getManagerStats_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getFieldValue(ManagerClientService.getManagerStats_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getFieldValue(ManagerClientService.initiateFlush_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
getFieldValue(ManagerClientService.initiateFlush_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getFieldValue(ManagerClientService.modifyNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getFieldValue(ManagerClientService.modifyNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getFieldValue(ManagerClientService.modifySystemProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
getFieldValue(ManagerClientService.modifySystemProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getFieldValue(ManagerClientService.modifyTableProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getFieldValue(ManagerClientService.modifyTableProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getFieldValue(ManagerClientService.removeNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getFieldValue(ManagerClientService.removeNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
getFieldValue(ManagerClientService.removeSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
getFieldValue(ManagerClientService.removeSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
getFieldValue(ManagerClientService.removeTableProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getFieldValue(ManagerClientService.removeTableProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
getFieldValue(ManagerClientService.reportSplitExtent_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getFieldValue(ManagerClientService.reportTabletStatus_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getFieldValue(ManagerClientService.setManagerGoalState_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
getFieldValue(ManagerClientService.setManagerGoalState_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
getFieldValue(ManagerClientService.setNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getFieldValue(ManagerClientService.setNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getFieldValue(ManagerClientService.setSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getFieldValue(ManagerClientService.setSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
getFieldValue(ManagerClientService.setTableProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getFieldValue(ManagerClientService.setTableProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getFieldValue(ManagerClientService.shutdown_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
getFieldValue(ManagerClientService.shutdown_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
getFieldValue(ManagerClientService.shutdownTabletServer_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
getFieldValue(ManagerClientService.shutdownTabletServer_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
getFieldValue(ManagerClientService.waitForBalance_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
getFieldValue(ManagerClientService.waitForBalance_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
getFieldValue(ManagerClientService.waitForFlush_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getFieldValue(ManagerClientService.waitForFlush_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
getFieldValue(ManagerMonitorInfo._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getFieldValue(RecoveryStatus._Fields) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
getFieldValue(TableInfo._Fields) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getFieldValue(TabletServerStatus._Fields) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getFieldValue(TabletSplit._Fields) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getFieldValue(ThriftPropertyException._Fields) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
getFieldValue(TAuthenticationKey._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getFieldValue(TAuthenticationTokenIdentifier._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getFieldValue(TCredentials._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getFieldValue(TDelegationToken._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
getFieldValue(TDelegationTokenConfig._Fields) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
getFieldValue(TabletManagementClientService.chop_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
getFieldValue(TabletManagementClientService.flushTablet_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
getFieldValue(TabletManagementClientService.loadTablet_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
getFieldValue(TabletManagementClientService.splitTablet_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
getFieldValue(TabletManagementClientService.splitTablet_result._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
getFieldValue(TabletManagementClientService.unloadTablet_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
getFieldValue(ConstraintViolationException._Fields) - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
getFieldValue(DataFileInfo._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
getFieldValue(TabletIngestClientService.applyUpdates_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
getFieldValue(TabletIngestClientService.closeConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
getFieldValue(TabletIngestClientService.closeUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
getFieldValue(TabletIngestClientService.closeUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
getFieldValue(TabletIngestClientService.conditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
getFieldValue(TabletIngestClientService.conditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
getFieldValue(TabletIngestClientService.invalidateConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
getFieldValue(TabletIngestClientService.invalidateConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
getFieldValue(TabletIngestClientService.loadFiles_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
getFieldValue(TabletIngestClientService.startConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getFieldValue(TabletIngestClientService.startConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
getFieldValue(TabletIngestClientService.startUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
getFieldValue(TabletIngestClientService.startUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
getFieldValue(TabletIngestClientService.update_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
getFieldValue(TabletIngestClientService.update_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
getFieldValue(ActiveScan._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getFieldValue(ScanServerBusyException._Fields) - Method in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
getFieldValue(TabletScanClientService.closeMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
getFieldValue(TabletScanClientService.closeMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
getFieldValue(TabletScanClientService.closeScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
getFieldValue(TabletScanClientService.continueMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
getFieldValue(TabletScanClientService.continueMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
getFieldValue(TabletScanClientService.continueScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
getFieldValue(TabletScanClientService.continueScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
getFieldValue(TabletScanClientService.getActiveScans_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
getFieldValue(TabletScanClientService.getActiveScans_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
getFieldValue(TabletScanClientService.startMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getFieldValue(TabletScanClientService.startMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
getFieldValue(TabletScanClientService.startScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getFieldValue(TabletScanClientService.startScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
getFieldValue(TooManyFilesException._Fields) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
getFieldValue(TSampleNotPresentException._Fields) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
getFieldValue(TSamplerConfiguration._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
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(InputFile._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getFieldValue(IteratorConfig._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getFieldValue(NoSuchScanIDException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
getFieldValue(NotServingTabletException._Fields) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
getFieldValue(TabletServerClientService.compact_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
getFieldValue(TabletServerClientService.compactionJobFailed_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
getFieldValue(TabletServerClientService.compactionJobFinished_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
getFieldValue(TabletServerClientService.contiuneGetSummaries_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
getFieldValue(TabletServerClientService.contiuneGetSummaries_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
getFieldValue(TabletServerClientService.fastHalt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
getFieldValue(TabletServerClientService.flush_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
getFieldValue(TabletServerClientService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
getFieldValue(TabletServerClientService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
getFieldValue(TabletServerClientService.getActiveLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
getFieldValue(TabletServerClientService.getActiveLogs_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
getFieldValue(TabletServerClientService.getCompactionQueueInfo_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
getFieldValue(TabletServerClientService.getCompactionQueueInfo_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
getFieldValue(TabletServerClientService.getHistoricalStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
getFieldValue(TabletServerClientService.getHistoricalStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
getFieldValue(TabletServerClientService.getTabletServerStatus_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
getFieldValue(TabletServerClientService.getTabletServerStatus_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
getFieldValue(TabletServerClientService.getTabletStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
getFieldValue(TabletServerClientService.getTabletStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
getFieldValue(TabletServerClientService.halt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
getFieldValue(TabletServerClientService.halt_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
getFieldValue(TabletServerClientService.removeLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
getFieldValue(TabletServerClientService.reserveCompactionJob_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
getFieldValue(TabletServerClientService.reserveCompactionJob_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
getFieldValue(TabletServerClientService.startGetSummaries_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
getFieldValue(TabletServerClientService.startGetSummaries_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
getFieldValue(TabletServerClientService.startGetSummariesForPartition_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
getFieldValue(TabletServerClientService.startGetSummariesForPartition_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
getFieldValue(TabletServerClientService.startGetSummariesFromFiles_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
getFieldValue(TabletServerClientService.startGetSummariesFromFiles_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
getFieldValue(TabletStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getFieldValue(TCompactionQueueSummary._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
getFieldValue(TCompactionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
getFieldValue(TExternalCompactionJob._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getFieldValue(TIteratorSetting._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getFile() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getFileDecrypter(CryptoEnvironment) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
getFileDecrypter(CryptoEnvironment) - Method in interface org.apache.accumulo.core.spi.crypto.CryptoService
Initialize the FileDecrypter for the environment and return.
getFileDecrypter(CryptoEnvironment) - Method in class org.apache.accumulo.core.spi.crypto.NoCryptoService
 
getFileDecrypter(CryptoService, CryptoEnvironment.Scope, TableId, DataInputStream) - Static method in class org.apache.accumulo.core.crypto.CryptoUtils
Read the decryption parameters from the DataInputStream and get the FileDecrypter associated with the provided CryptoService and CryptoEnvironment.Scope.
getFileEncrypter(CryptoEnvironment) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
getFileEncrypter(CryptoEnvironment) - Method in interface org.apache.accumulo.core.spi.crypto.CryptoService
Initialize the FileEncrypter for the environment and return.
getFileEncrypter(CryptoEnvironment) - Method in class org.apache.accumulo.core.spi.crypto.NoCryptoService
 
getFileLenCache() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getFilename() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
getFileName() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
getFileName() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
getFileName() - Method in class org.apache.accumulo.core.data.LoadPlan.Destination
 
getFileName() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getFileName() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile.FileParts
 
getFileName() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
 
getFileName() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
 
getFileName() - Method in interface org.apache.accumulo.core.metadata.TabletFile
Returns the fileName of the TabletFile.
getFileName() - Method in class org.apache.accumulo.core.metadata.UnreferencedTabletFile
 
getFilenames() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
getFilenamesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
getFilenamesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
getFiles() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Mapping
 
getFiles() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getFiles() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionJob
 
getFiles() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
getFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getFiles() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
getFilesContaining() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getFilesExceeding() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getFilesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getFileSize() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getFileSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
getFileSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
getFileSize(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.FileOperations
 
getFileSize(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
getFilesLarge() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getFilesMap() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
getFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getFileStatistics() - Method in class org.apache.accumulo.core.client.summary.Summary
 
getFilesToCompact() - Method in class org.apache.accumulo.core.client.admin.compaction.CompactionSelector.Selection
 
getFileSystem() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getFileSystem() - Method in interface org.apache.accumulo.core.volume.Volume
A FileSystem that Accumulo will use
getFileSystem() - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
getFinalState() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
getFinished() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getFirst() - Method in class org.apache.accumulo.core.util.Pair
 
getFirstKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getFirstKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getFirstKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getFirstKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getFixedMemoryAsBytes(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Interprets a string specifying bytes.
getFlush() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getFlushes() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getFlushes() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getFlushId() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getFlushID() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getFlushs() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getFormatter(Class<? extends Formatter>, Iterable<Map.Entry<Key, Value>>, FormatterConfig) - Static method in class org.apache.accumulo.core.util.format.FormatterFactory
 
getFormatter(String) - Method in class org.apache.accumulo.core.file.rfile.PrintInfo
 
getFraction(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Interprets a string specifying a fraction.
getFraction(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.FRACTION, interpreting the value properly.
getFreeSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the current size of this cache.
getFreeSpace(String) - Method in class org.apache.accumulo.core.spi.fs.SpaceAwareVolumeChooser
 
getFullScans() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFullScansIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFullScansSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getFullyQualifiedOption(String) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.InitParameters
 
getFullyQualifiedOption(String) - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getFullyQualifiedPropertyPrefix(Property, String) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getFullyQualifiedPropertyPrefix(Property, String, CacheType) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getFutureServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getGcCandidates(Ample.DataLevel) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
 
getGoal() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
getGoalState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getGroup() - Method in class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptor
 
getGroup() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerInfo
 
getGroup(ServiceLockData.ThriftService) - Method in class org.apache.accumulo.core.lock.ServiceLockData
 
getHadoopConf() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve the hadoop configuration
getHadoopConf() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getHadoopConf() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getHeaders() - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
getHeadersSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
getHeldLocks() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getHints() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.SelectorParameters
 
getHistoricalStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getHistoricalStats
 
getHistoricalStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getHistoricalStats
 
getHistoricalStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
getHistoricalStats(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
getHistoricalStats(TInfo, TCredentials, AsyncMethodCallback<TabletStats>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
getHistoricalStats(TInfo, TCredentials, AsyncMethodCallback<TabletStats>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
getHistoricalStats_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
getHistoricalStats_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
getHistoricalStats_args(TabletServerClientService.getHistoricalStats_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
Performs a deep copy on other.
getHistoricalStats_call(TInfo, TCredentials, AsyncMethodCallback<TabletStats>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getHistoricalStats_call
 
getHistoricalStats_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
getHistoricalStats_result(TabletServerClientService.getHistoricalStats_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
Performs a deep copy on other.
getHistoricalStats_result(TabletStats, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
getHitRatio() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getHoldTime() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getHoldTime() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getHoldTime() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getHost() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
Return the host where the compaction is running.
getHost() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getHost() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
getHost() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getHost() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getHost() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletServerId
 
getHostAndPort() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getHostAndPort() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getHostPort() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getHostPort() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getHostPortSession() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getHostPortSession() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getHostPortString(HostAndPort) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
Utility for returning the address of a service in the form host:port
getId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getId() - Method in enum org.apache.accumulo.core.security.NamespacePermission
Gets the byte ID of this permission.
getId() - Method in enum org.apache.accumulo.core.security.SystemPermission
Gets the byte ID of this permission.
getId() - Method in enum org.apache.accumulo.core.security.TablePermission
Gets the byte ID of this permission.
getIdentifier() - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
The identifier for this token, may be null.
getIdentifier() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
getIdleTime() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getIdleTime() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getIdleTime() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getIdleTimeStats() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
Returns statistics about the time between running.
getIdleTimeStats(long) - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
This method is similar to ScanInfo.getIdleTimeStats(), but it also includes the time period between the last run time and now in the stats.
getIds() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionServices
 
getIdtoNameMap() - Method in class org.apache.accumulo.core.util.tables.TableMap
 
getIdToNameMap(ClientContext) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Return sorted map with key = ID, value = namespaceName
getIgnored() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getInaccurate() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getIndex() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getIndex(Supplier<BlockIndex>) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getIndex(Supplier<T>) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
getIndex(Supplier<T>) - Method in interface org.apache.accumulo.core.spi.cache.CacheEntry
Optionally cache what is returned by the supplier along with this cache entry.
getIndex(CachableBlockFile.CachedBlockRead, MultiLevelIndex.IndexEntry) - Static method in class org.apache.accumulo.core.file.rfile.BlockIndex
 
getIndexCache() - Method in class org.apache.accumulo.core.file.blockfile.impl.BasicCacheProvider
 
getIndexCache() - Method in interface org.apache.accumulo.core.file.blockfile.impl.CacheProvider
 
getIndexCache() - Method in class org.apache.accumulo.core.file.blockfile.impl.ScanCacheProvider
 
getIndexCacheHits() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getIndexCacheHits() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getIndexCacheHits() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getIndexCacheRequest() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getIndexCacheRequests() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getIndexCacheRequests() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getIndexCacheUsage() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch
 
getIndexInfo(Map<Integer, Long>, Map<Integer, Long>) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
getIngestByteRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getIngestByteRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getIngestByteRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getIngestRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getIngestRate() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getIngestRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getIngestRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getIngestRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getIngestRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getInitiallySelecteAll() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getInitialTableState() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Return value indicating whether table is to be created in offline or online mode.
getInputFiles() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getInputFiles() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InputParameters
 
getInputFiles() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getInputFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputFilesIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputFilesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getInputStream() - Method in class org.apache.accumulo.core.client.rfile.RFileSource
 
getInstance() - Static method in class org.apache.accumulo.core.conf.DefaultConfiguration
Gets a default configuration.
getInstance() - Static method in class org.apache.accumulo.core.file.FileOperations
 
getInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheManagerFactory
Get the BlockCacheFactory specified by the property 'tserver.cache.factory.class' using the System class loader
getInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory
Get the singleton instance of the SharedRateLimiterFactory.
getInstanceId() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getInstanceId
 
getInstanceId() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getInstanceId
 
getInstanceId() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Returns a unique ID object that identifies this instance of accumulo.
getInstanceId() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getInstanceId() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getInstanceId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getInstanceId() - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getInstanceId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getInstanceId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getInstanceId(AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getInstanceId(AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getInstanceID() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns a unique string that identifies this instance of accumulo.
getInstanceId_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
getInstanceId_args(ClientService.getInstanceId_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
Performs a deep copy on other.
getInstanceId_call(AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getInstanceId_call
 
getInstanceId_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
getInstanceId_result(String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
getInstanceId_result(ClientService.getInstanceId_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
Performs a deep copy on other.
getInstanceName() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns the instance name given at system initialization time.
getInstanceName() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getInstanceName() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getInt(KT) - Method in class org.apache.accumulo.core.util.MapCounter
 
getInteger(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getIssueDate() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getIssueDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getIterator() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroup
 
getIteratorClass() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the name of the class that implements the iterator.
getIteratorClass() - Method in interface org.apache.accumulo.core.spi.common.IteratorConfiguration
 
getIteratorClass() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getIterators() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getIterators() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getIterators() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getIterators() - Method in class org.apache.accumulo.core.data.Condition
Gets the iterators for this condition.
getIterators() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getIterators() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIteratorSamplerConfiguration() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getIteratorScope() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Return the executed scope of the Iterator.
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Get the settings for an iterator.
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Get the settings for an iterator.
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
getIteratorSetting(String, String, IteratorUtil.IteratorScope) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
getIteratorSettings() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getIteratorsIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIteratorsSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
getIterName() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
getJob() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getJob() - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
getJobFiles() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getJobs() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlan
Return the set of jobs this plan will submit for compaction.
getJobs() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlanImpl
 
getKerberosServerPrimary() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The 'primary' component from the Kerberos principals that servers are configured to use.
getKey() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getKey() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getKey() - Method in enum org.apache.accumulo.core.conf.Property
Gets the key (string) for this property.
getKey() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
getKey() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getKey() - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
getKeyExtent() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
getKeyExtent() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
getKeyExtent(TableId) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Mapping
 
getKeyId() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getKeyId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getKeyId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getKeyPrefix() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates the prefix of keys that will be transformed by this iterator.
getKeys(Configuration) - Static method in class org.apache.accumulo.core.conf.HadoopCredentialProvider
Attempt to extract all aliases from any configured CredentialProviders.
getKeyStorePass() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getKeyStorePath() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getKeyStoreType() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getKeytab() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
The keytab file used to perform Kerberos login.
getKeyValues() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getKind() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getKind() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getKind() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionJob
 
getKind() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getKind() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getKind() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
getKVCount() - Method in class org.apache.accumulo.core.client.RowIterator
Get a count of the total number of entries in all rows read so far.
getLarge() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getLast() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getLast() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getLastColumnFamilies() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroupSeekCache
 
getLastContact() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getLastContact() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getLastContact() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getLastContactTime() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getLastContactTime() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getLastKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getLastKey() - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getLastKey() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
getLastKey() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getLastKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
getLastRunTime() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
If the scan has run, returns the last run time.
getLastServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getLastStatus() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
getLastUsed() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroupSeekCache
 
getLength() - Method in class org.apache.accumulo.core.client.rfile.RFileSource
 
getLength() - Method in class org.apache.accumulo.core.data.Key
Returns the sums of the lengths of the row, column family, column qualifier, and column visibility.
getLength() - Method in class org.apache.accumulo.core.dataImpl.ComparableBytes
 
getLength() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
getLength() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
getLength() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
 
getLength() - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
getLength() - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
getLifetime() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
getLiveTServers(ClientContext) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
Get the tservers that are live from ZK.
getLoadBalancerClassNameForTable(TableId) - Method in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
getLoaded() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getLocalityGroup() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getLocalityGroup() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getLocalityGroup() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getLocalityGroupCF() - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getLocalityGroups(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets the locality groups currently set for a table.
getLocalityGroups(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getLocalityGroups(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
getLocalityGroupsIgnoringErrors(AccumuloConfiguration, TableId) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
getLocation() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getLocation() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getLocation(ClientContext) - Static method in class org.apache.accumulo.core.util.MonitorUtil
 
getLocationless() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocations
 
getLocationProvider() - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
getLocations() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocations
 
getLocator(ClientContext, TableId) - Static method in class org.apache.accumulo.core.clientImpl.TabletLocator
 
getLock() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
getLock() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
getLock() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
getLock() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
getLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
getLockData(ZooCache, ServiceLock.ServiceLockPath, ZooCache.ZcStat) - Static method in class org.apache.accumulo.core.lock.ServiceLock
 
getLockData(ServiceLock.ServiceLockPath) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
 
getLockData(ZooKeeper, ServiceLock.ServiceLockPath) - Static method in class org.apache.accumulo.core.lock.ServiceLock
 
getLockID() - Method in class org.apache.accumulo.core.lock.ServiceLock
 
getLockName() - Method in class org.apache.accumulo.core.lock.ServiceLock
 
getLockPath() - Method in class org.apache.accumulo.core.lock.ServiceLock
 
getLogInterval() - Method in class org.apache.accumulo.core.util.Retry
 
getLogs() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getLogSorts() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getLogSortsIterator() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getLogSortsSize() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getLookups() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getLookups() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getLookups() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getMajors() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getMajors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getManagerConnection(Logger, ThriftClientTypes<C>, ClientContext) - Method in interface org.apache.accumulo.core.rpc.clients.ManagerClient
 
getManagerLocations() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Returns the location(s) of the accumulo manager and any redundant servers.
getManagerLocations() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns the location(s) of the accumulo manager and any redundant servers.
getManagerLocations() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getManagerStats() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getManagerStats
 
getManagerStats() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getManagerStats
 
getManagerStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
getManagerStats(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
getManagerStats(TInfo, TCredentials, AsyncMethodCallback<ManagerMonitorInfo>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
getManagerStats(TInfo, TCredentials, AsyncMethodCallback<ManagerMonitorInfo>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
getManagerStats_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getManagerStats_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getManagerStats_args(ManagerClientService.getManagerStats_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
Performs a deep copy on other.
getManagerStats_call(TInfo, TCredentials, AsyncMethodCallback<ManagerMonitorInfo>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getManagerStats_call
 
getManagerStats_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getManagerStats_result(ManagerClientService.getManagerStats_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
Performs a deep copy on other.
getManagerStats_result(ManagerMonitorInfo, ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getMapConcurrencyLevel() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMapLoadFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMask() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
getMaxEntrySize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getMaxEntrySize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.SynchronousLoadingBlockCache
Get the maximum size of an individual cache entry.
getMaxFilesPerTablet() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets the maximum number of files per tablet from this configuration.
getMaxHeapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getMaxHeapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getMaxHeapSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getMaxHeapSize() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Get the maximum amount of on heap memory this cache will use.
getMaxLatency(TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxLoops() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getMaxMemory() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxMigrations() - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
The maximum number of migrations to perform in a single pass.
getMaxMigrations() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getMaxOutstandingMigrations() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getMaxRow(String, Authorizations, Text, boolean, Text, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Finds the max row within a given range.
getMaxRow(String, Authorizations, Text, boolean, Text, boolean) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getMaxSize() - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getMaxSize() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Get the maximum size of this cache.
getMaxSize(CacheType) - Method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getMaxSize(CacheType) - Method in interface org.apache.accumulo.core.spi.cache.BlockCacheManager.Configuration
Before Accumulo's cache implementation was configurable, its built in caches had a configurable size.
getMaxThreads() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor.Config
 
getMaxWriteThreads() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getMaxWriteThreads() - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getMechanism() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The SASL mechanism to use for authentication
getMechanismName() - Method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
 
getMemoryAsBytes(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Interprets a string specifying a Memory type which is specified as a long integer followed by an optional B (bytes), K (KB), M (MB), G (GB) or % (percentage).
getMemoryFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMessage() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getMessage() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getMessage() - Method in exception org.apache.accumulo.core.security.VisibilityParseException
 
getMetaBlock(long, long, long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
getMetaBlock(String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
It is intended that once the BlockRead object is returned to the caller, that the caller will read the entire block and then call close on the BlockRead class.
getMetaBlock(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
Stream access to a Meta Block.
getMetaBlockRawSize(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
getMetadataEntry() - Method in interface org.apache.accumulo.core.gc.Reference
Get the exact string stored in the metadata table for this file or directory.
getMetadataEntry() - Method in class org.apache.accumulo.core.gc.ReferenceDirectory
A Tablet directory should have a metadata entry equal to the dirName.
getMetadataEntry() - Method in class org.apache.accumulo.core.gc.ReferenceFile
 
getMetadataFileEntry() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getMetadataLocationEntries(SortedMap<Key, Value>) - Static method in class org.apache.accumulo.core.metadata.MetadataLocationObtainer
 
getMetaInsert() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
Return a string for inserting a new tablet file.
getMetaInsertText() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
Return a new Text object of ReferencedTabletFile.getMetaInsert()
getMetaStore(String) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getMetaStore(String) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getMetaStore(String) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getMetaStore(String) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getMetaUpdateDelete() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
Return the exact string that is stored in the metadata table.
getMetaUpdateDeleteText() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
Return a new Text object of StoredTabletFile.getMetaUpdateDelete()
getMetricFields() - Method in interface org.apache.accumulo.core.metrics.MetricsProducer
Returns a new mutable mapping of metric field value to metric field name.
getMetrics() - Method in interface org.apache.accumulo.core.file.rfile.MetricsGatherer
 
getMetrics() - Method in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
getMigrations(Map<TabletServerId, TServerStatus>, List<TabletMigration>) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
getMinFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMinors() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getMinors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getMissCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getMissing() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getMissRatio() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
getMode() - Static method in class org.apache.accumulo.core.singletons.SingletonManager
 
getModulus() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
getMultiFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getMutation() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
 
getMutation() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
getMutation() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
getMutations() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletServerMutations
 
getMutations() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
getMutations() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
getMutationsIterator() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
getMutationsSize() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
getMutationsSize() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
getMzxid() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache.ZcStat
 
getName() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the iterator's name.
getName() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
getName() - Method in interface org.apache.accumulo.core.fate.ReadOnlyRepo
 
getName() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
getName() - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
Returns the name of the compression algorithm.
getName() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getName() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getName() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
getName() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getName() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getName() - Method in interface org.apache.accumulo.core.spi.common.IteratorConfiguration
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Bzip2
 
getName() - Method in interface org.apache.accumulo.core.spi.file.rfile.compression.CompressionAlgorithmConfiguration
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
getName() - Method in class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
getName() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor.Config
 
getName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getNamedOptions() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getNameFromIp(String) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
getNamespaceConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceConfiguration
 
getNamespaceConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getNamespaceConfiguration(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getNamespaceConfiguration(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getNamespaceConfiguration(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getNamespaceConfiguration_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getNamespaceConfiguration_args(ClientService.getNamespaceConfiguration_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
Performs a deep copy on other.
getNamespaceConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getNamespaceConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
 
getNamespaceConfiguration_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getNamespaceConfiguration_result(Map<String, String>, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getNamespaceConfiguration_result(ClientService.getNamespaceConfiguration_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
Performs a deep copy on other.
getNamespaceId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getNamespaceId(ClientContext, String) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Look for namespace ID in ZK.
getNamespaceId(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getNamespaceId(TableId) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Returns the namespace id for a given table ID.
getNamespaceName() - Method in exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
getNamespaceName() - Method in exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
getNamespaceName(ClientContext, NamespaceId) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Look for namespace name in ZK.
getNamespaceProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceProperties
 
getNamespaceProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceProperties
 
getNamespaceProperties(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Gets properties specific to this namespace.
getNamespaceProperties(String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
getNamespaceProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getNamespaceProperties(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getNamespaceProperties(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getNamespaceProperties(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getNamespaceProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getNamespaceProperties_args(ClientService.getNamespaceProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
Performs a deep copy on other.
getNamespaceProperties_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getNamespaceProperties_call(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceProperties_call
 
getNamespaceProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getNamespaceProperties_result(Map<String, String>, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getNamespaceProperties_result(ClientService.getNamespaceProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
Performs a deep copy on other.
getNameToIdMap() - Method in class org.apache.accumulo.core.util.tables.TableMap
 
getNameToIdMap(ClientContext) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Return sorted map with key = namespaceName, value = ID
getNewDataSource() - Method in interface org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator.DataSource
 
getNewFileExtension(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.file.FileOperations
 
getNewTablets() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getNewTabletServer() - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
getNewTabletsIterator() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getNewTabletsSize() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getNewZooCache(String, int) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCacheFactory
Always return a new ZooCache.
getNextFiles() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getNextKeyHint(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
 
getNextKeyHint(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
Whenever the subclass returns AdvanceResult.USE_HINT from its filter predicate, this method will be called to see how far to advance the source iterator.
getNormalizedPath() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile.FileParts
 
getNormalizedPathStr() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
Return a string for opening and reading the tablet file.
getNormalizedPathStr() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getNssi() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
getNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
getNste() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
getNste() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
getNste() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
getNste() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
getNum() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
getNumEntries() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getNumEntries() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getNumEntries() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getNumEntries() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getNumLGSeeked() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroupSeekCache
 
getNumThreads(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Get the number of threads from string property.
getObject(Key) - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnToClassMapping
 
getOffset() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getOldPrevEndRow() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getOldTablet() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
getOldTabletServer() - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
getOnlineTabletCount() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getOnlineTabletCount() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getOnlineTablets() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getOnlineTabletsForTable(TabletServerId, TableId) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getOnlineTabletsForTable(TabletServerId, TableId) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
getOobCheckMillis() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getOp() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getOp() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
getOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
getOptions() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InitParameters
 
getOptions() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.InitParameters
 
getOptions() - Method in class org.apache.accumulo.core.client.admin.PluginConfig
 
getOptions() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get the configuration parameters for this iterator.
getOptions() - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
getOptions() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
 
getOptions() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getOptions() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getOptions() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
getOptions() - Method in interface org.apache.accumulo.core.spi.common.IteratorConfiguration
 
getOptions() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.InitParameters
 
getOptions() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.InitParameters
 
getOptions() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.InitParameters
 
getOptions() - Method in interface org.apache.accumulo.core.spi.scan.ScanPrioritizer.CreateParameters
 
getOptions() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.InitParameters
 
getOptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
getOptions() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getOptions() - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
getOptionsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
getOptionsSize() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getOptionsSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
getOsLoad() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getOsLoad() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getOsLoad() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getOutputFile() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getOutputFile() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getOutputStream() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getOverhead() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
getOverrides() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getOverrides() - Method in class org.apache.accumulo.core.cli.ConfigOpts
 
getOverrides() - Method in class org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.Overrides
 
getOverrides() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getOverrides(List<String>) - Static method in class org.apache.accumulo.core.cli.ConfigOpts
 
getOverridesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getParent() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
get a parent configuration or null if it does not exist.
getParent() - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getParseTree() - Method in class org.apache.accumulo.core.security.ColumnVisibility
Gets the parse tree for this column visibility.
getPartition(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getPartitioner() - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
getPartitioner() - Method in class org.apache.accumulo.core.spi.balancer.RegexGroupBalancer
 
getPartNextKey() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getPartScan() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getPassword() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
getPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getPassword() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
getPassword(SecretManager<T>, T) - Method in class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
Generate the password from the provided SecretManager and TokenIdentifier.
getPath() - Method in class org.apache.accumulo.core.metadata.AbstractTabletFile
 
getPath() - Method in interface org.apache.accumulo.core.metadata.TabletFile
Returns the full path for the TabletFile on the file system.
getPath(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.PATH.
getPausedCount() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getPausedCount() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Gets the permission matching the given byte ID.
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.SystemPermission
Gets the permission matching the given byte ID.
getPermissionById(byte) - Static method in enum org.apache.accumulo.core.security.TablePermission
Gets the permission matching the given byte ID.
getPlanners() - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
getPluginEnv() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Returns an object containing information about the server where this iterator was run.
getPoolNameForTable(String) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
Matches table name against pool names, returns matching pool name or DEFAULT_POOL.
getPoolNamesForHost(TabletServerId) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
Matches host against the regexes and returns the matching pool names
getPoolNameToRegexPattern() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
getPort() - Method in interface org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost
 
getPort() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
getPort() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletServerId
 
getPort(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).
getPortStream(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
getPos() - Method in class org.apache.accumulo.core.file.streams.RateLimitedInputStream
 
getPos() - Method in class org.apache.accumulo.core.file.streams.SeekableDataInputStream
 
getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
getPosition() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
getPositionAndReset() - Method in class org.apache.accumulo.core.iterators.YieldCallback
Called by the client to get the yield position used as the start key (non-inclusive) of the range in a subsequent seek call when the iterator is rebuilt.
getPrefix(Properties, String) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
getPrevEndRow() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Tablet
 
getPrevEndRow() - Method in interface org.apache.accumulo.core.data.TabletId
 
getPrevEndRow() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
getPrevEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
getPrevEndRow() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getPrevKey() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
getPrincipal() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
The identity of the user to which this token belongs to according to Kerberos
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getPrincipal() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.Credentials
Gets the principal.
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getPrincipal() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The principal of the logged in user for SASL
getPrincipal() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
getPrincipal() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getPrintableTableInfoFromId(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getPrintableTableInfoFromId(TableId) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
getPrintableTableInfoFromName(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getPrintableTableInfoFromName(String) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
getPrioritizerClass() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor.Config
 
getPrioritizerOptions() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor.Config
 
getPriority() - Method in class org.apache.accumulo.core.client.IteratorSetting
Get layer at which this iterator applies.
getPriority() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
getPriority() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
getPriority() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getPriority() - Method in interface org.apache.accumulo.core.spi.common.IteratorConfiguration
 
getPriority() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionJob
 
getPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
getPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
getPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getPriority() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
getProgress() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
getPropagateDeletes() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
getProperties() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Retrieves the complete set of currently configured table properties to be applied to a table when this configuration object is used.
getProperties() - Method in interface org.apache.accumulo.core.client.security.tokens.AuthenticationToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
getProperties() - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getProperties() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
getProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
getProperties() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getProperties(String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Gets 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, CacheType) - Method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
getProperties(String, CacheType) - Method in interface org.apache.accumulo.core.spi.cache.BlockCacheManager.Configuration
This method provides a way for a cache implementation to access arbitrary configuration set by a user.
getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Returns property key/value pairs in this configuration.
getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
getProperties(Map<String, String>, Predicate<String>) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getProperties(Map<String, String>, Predicate<String>, boolean) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
getPropertiesPath() - Method in class org.apache.accumulo.core.cli.ConfigOpts
 
getPropertiesSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
getPropertiesSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
getPropertiesToExclude() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
The source table properties are copied, this allows reverting to system defaults for some of those properties.
getPropertiesToExclude() - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
getPropertiesToSet() - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration
The source table properties are copied.
getPropertiesToSet() - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getProperty() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
getProperty(IteratorUtil.IteratorScope) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
Fetch the correct configuration key prefix for the given scope.
getPropertyByKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
Gets a Property instance with the given key.
getPropertyId() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
The propertyId is used when creating table properties for a summarizer.
getPropertyRenamers() - Static method in class org.apache.accumulo.core.conf.DeprecatedPropertyUtil
 
getProtocol(TTransport) - Method in class org.apache.accumulo.core.rpc.TraceProtocolFactory
 
getQualifier() - Method in class org.apache.accumulo.core.data.Condition
Gets the column qualifier of this condition.
getQuality() - Method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
 
getQualityOfProtection() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
The quality of protection used with SASL.
getQueryByteRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getQueryByteRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getQueryByteRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getQueryRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getQueryRate() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getQueryRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getQueryRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getQueryRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getQueryRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getQueue() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
getQueued() - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
getQueued() - Method in interface org.apache.accumulo.core.spi.scan.ScanExecutor
 
getQueueName() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getQueueName() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getQueueName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
getQueueName() - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
getQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getRange() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getRange() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getRange() - Method in interface org.apache.accumulo.core.client.Scanner
Returns the range of keys to scan over.
getRange() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
getRange() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getRange() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ExternalCompactionSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ProblemSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ScanServerFileReferenceSection
 
getRange() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
getRange() - Method in class org.apache.accumulo.core.schema.Section
 
getRange() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getRange(TableId) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
getRangeType() - Method in class org.apache.accumulo.core.data.LoadPlan.Destination
 
getRate() - Method in class org.apache.accumulo.core.util.ratelimit.GuavaRateLimiter
 
getRate() - Method in class org.apache.accumulo.core.util.ratelimit.NullRateLimiter
 
getRate() - Method in interface org.apache.accumulo.core.util.ratelimit.RateLimiter
Get current QPS of the rate limiter, with a non-positive rate indicating no limit.
getRateLimit(String) - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
getRateLimiter() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getRateLimits() - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
getRatio() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader.BlockReader
Get the uncompressed size of the block.
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
Get the raw size of the block.
getRawSize() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
getReadaheadThreshold() - Method in interface org.apache.accumulo.core.client.Scanner
The number of batches of Key/Value pairs returned before the Scanner will begin to prefetch the next batch
getReadaheadThreshold() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
getReadaheadThreshold() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getReason() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getReason() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getReason() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getRecords() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getRecords() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getRecordsInMemory() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getRecordsInMemory() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getRecs() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getRecsInMemory() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getRemainder() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
getRemaining() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
getReplacementName(String, BiConsumer<Logger, String>) - Static method in class org.apache.accumulo.core.conf.DeprecatedPropertyUtil
Checks if propertyName is a deprecated property name and return its replacement name, if one is available, or the original name if no replacement is available.
getRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
getRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
getRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
getRequestedExecutors() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getRequestedExternalExecutors() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getRequestTime() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
getReservationCount() - Static method in class org.apache.accumulo.core.singletons.SingletonManager
 
getResponseTime() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getResponseTime() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getResponseTime() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.authenticate_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.authenticateUser_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.changeAuthorizations_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkClass_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkTableClass_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.createLocalUser_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.dropLocalUser_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getDiskUsage_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getInstanceId_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getSystemProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableConfiguration_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedNamespaceProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedSystemProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedTableProperties_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getZooKeepers_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantTablePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasTablePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.isActive_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.listLocalUsers_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.ping_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeTablePermission_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.fails_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.success_call
 
getResult() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.throwsError_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.cancel_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.compactionCompleted_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.compactionFailed_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompactionJob_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompletedCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getRunningCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.updateCompactionStatus_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.cancel_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getActiveCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompaction_call
 
getResult() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompactionId_call
 
getResult() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
getResult() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
getResult() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.beginFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.cancelFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.executeFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.finishFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.waitForFateOperation_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getActiveTservers_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getDelegationToken_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getManagerStats_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.initiateFlush_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifyNamespaceProperties_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifySystemProperties_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifyTableProperties_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeNamespaceProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeSystemProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeTableProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.reportSplitExtent_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.reportTabletStatus_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setManagerGoalState_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setNamespaceProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setSystemProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setTableProperty_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.shutdown_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.shutdownTabletServer_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.waitForBalance_call
 
getResult() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.waitForFlush_call
 
getResult() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerAttempt
 
getResult() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.chop_call
 
getResult() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.flushTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.loadTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.splitTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.unloadTablet_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.applyUpdates_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.closeConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.closeUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.conditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.invalidateConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.loadFiles_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.startConditionalUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.startUpdate_call
 
getResult() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.update_call
 
getResult() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.closeMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.closeScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.continueMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.continueScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.getActiveScans_call
 
getResult() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.startMultiScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.startScan_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.compact_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.compactionJobFailed_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.compactionJobFinished_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.contiuneGetSummaries_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.fastHalt_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.flush_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getActiveCompactions_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getActiveLogs_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getCompactionQueueInfo_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getHistoricalStats_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getTabletServerStatus_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getTabletStats_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.halt_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.removeLogs_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.reserveCompactionJob_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummaries_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummariesForPartition_call
 
getResult() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummariesFromFiles_call
 
getResult(I, ClientService.authenticate_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticate
 
getResult(I, ClientService.authenticateUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticateUser
 
getResult(I, ClientService.changeAuthorizations_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeAuthorizations
 
getResult(I, ClientService.changeLocalUserPassword_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeLocalUserPassword
 
getResult(I, ClientService.checkClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkClass
 
getResult(I, ClientService.checkNamespaceClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkNamespaceClass
 
getResult(I, ClientService.checkTableClass_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkTableClass
 
getResult(I, ClientService.createLocalUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.createLocalUser
 
getResult(I, ClientService.dropLocalUser_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.dropLocalUser
 
getResult(I, ClientService.getConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getConfiguration
 
getResult(I, ClientService.getDiskUsage_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getDiskUsage
 
getResult(I, ClientService.getInstanceId_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getInstanceId
 
getResult(I, ClientService.getNamespaceConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceConfiguration
 
getResult(I, ClientService.getNamespaceProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceProperties
 
getResult(I, ClientService.getRootTabletLocation_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getRootTabletLocation
 
getResult(I, ClientService.getSystemProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getSystemProperties
 
getResult(I, ClientService.getTableConfiguration_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableConfiguration
 
getResult(I, ClientService.getTableProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableProperties
 
getResult(I, ClientService.getUserAuthorizations_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getUserAuthorizations
 
getResult(I, ClientService.getVersionedNamespaceProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedNamespaceProperties
 
getResult(I, ClientService.getVersionedSystemProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedSystemProperties
 
getResult(I, ClientService.getVersionedTableProperties_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedTableProperties
 
getResult(I, ClientService.getZooKeepers_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getZooKeepers
 
getResult(I, ClientService.grantNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantNamespacePermission
 
getResult(I, ClientService.grantSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantSystemPermission
 
getResult(I, ClientService.grantTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantTablePermission
 
getResult(I, ClientService.hasNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasNamespacePermission
 
getResult(I, ClientService.hasSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasSystemPermission
 
getResult(I, ClientService.hasTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasTablePermission
 
getResult(I, ClientService.isActive_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.isActive
 
getResult(I, ClientService.listLocalUsers_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.listLocalUsers
 
getResult(I, ClientService.ping_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.ping
 
getResult(I, ClientService.revokeNamespacePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeNamespacePermission
 
getResult(I, ClientService.revokeSystemPermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeSystemPermission
 
getResult(I, ClientService.revokeTablePermission_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeTablePermission
 
getResult(I, ThriftTest.fails_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.fails
 
getResult(I, ThriftTest.success_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.success
 
getResult(I, ThriftTest.throwsError_args) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.throwsError
 
getResult(I, CompactionCoordinatorService.cancel_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.cancel
 
getResult(I, CompactionCoordinatorService.compactionCompleted_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionCompleted
 
getResult(I, CompactionCoordinatorService.compactionFailed_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionFailed
 
getResult(I, CompactionCoordinatorService.getCompactionJob_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompactionJob
 
getResult(I, CompactionCoordinatorService.getCompletedCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompletedCompactions
 
getResult(I, CompactionCoordinatorService.getRunningCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getRunningCompactions
 
getResult(I, CompactionCoordinatorService.updateCompactionStatus_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.updateCompactionStatus
 
getResult(I, CompactorService.cancel_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.cancel
 
getResult(I, CompactorService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getActiveCompactions
 
getResult(I, CompactorService.getRunningCompaction_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompaction
 
getResult(I, CompactorService.getRunningCompactionId_args) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompactionId
 
getResult(I, GCMonitorService.getStatus_args) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
getResult(I, FateService.beginFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.beginFateOperation
 
getResult(I, FateService.cancelFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.cancelFateOperation
 
getResult(I, FateService.executeFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.executeFateOperation
 
getResult(I, FateService.finishFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.finishFateOperation
 
getResult(I, FateService.waitForFateOperation_args) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.waitForFateOperation
 
getResult(I, ManagerClientService.getActiveTservers_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getActiveTservers
 
getResult(I, ManagerClientService.getDelegationToken_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getDelegationToken
 
getResult(I, ManagerClientService.getManagerStats_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getManagerStats
 
getResult(I, ManagerClientService.initiateFlush_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.initiateFlush
 
getResult(I, ManagerClientService.modifyNamespaceProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyNamespaceProperties
 
getResult(I, ManagerClientService.modifySystemProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifySystemProperties
 
getResult(I, ManagerClientService.modifyTableProperties_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyTableProperties
 
getResult(I, ManagerClientService.removeNamespaceProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeNamespaceProperty
 
getResult(I, ManagerClientService.removeSystemProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeSystemProperty
 
getResult(I, ManagerClientService.removeTableProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeTableProperty
 
getResult(I, ManagerClientService.reportSplitExtent_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportSplitExtent
 
getResult(I, ManagerClientService.reportTabletStatus_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportTabletStatus
 
getResult(I, ManagerClientService.setManagerGoalState_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setManagerGoalState
 
getResult(I, ManagerClientService.setNamespaceProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setNamespaceProperty
 
getResult(I, ManagerClientService.setSystemProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setSystemProperty
 
getResult(I, ManagerClientService.setTableProperty_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setTableProperty
 
getResult(I, ManagerClientService.shutdown_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdown
 
getResult(I, ManagerClientService.shutdownTabletServer_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdownTabletServer
 
getResult(I, ManagerClientService.waitForBalance_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForBalance
 
getResult(I, ManagerClientService.waitForFlush_args) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForFlush
 
getResult(I, TabletManagementClientService.chop_args) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.chop
 
getResult(I, TabletManagementClientService.flushTablet_args) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.flushTablet
 
getResult(I, TabletManagementClientService.loadTablet_args) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.loadTablet
 
getResult(I, TabletManagementClientService.splitTablet_args) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.splitTablet
 
getResult(I, TabletManagementClientService.unloadTablet_args) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.unloadTablet
 
getResult(I, TabletIngestClientService.applyUpdates_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.applyUpdates
 
getResult(I, TabletIngestClientService.closeConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.closeConditionalUpdate
 
getResult(I, TabletIngestClientService.closeUpdate_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.closeUpdate
 
getResult(I, TabletIngestClientService.conditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.conditionalUpdate
 
getResult(I, TabletIngestClientService.invalidateConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.invalidateConditionalUpdate
 
getResult(I, TabletIngestClientService.loadFiles_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.loadFiles
 
getResult(I, TabletIngestClientService.startConditionalUpdate_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startConditionalUpdate
 
getResult(I, TabletIngestClientService.startUpdate_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startUpdate
 
getResult(I, TabletIngestClientService.update_args) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.update
 
getResult(I, TabletScanClientService.closeMultiScan_args) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.closeMultiScan
 
getResult(I, TabletScanClientService.closeScan_args) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.closeScan
 
getResult(I, TabletScanClientService.continueMultiScan_args) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.continueMultiScan
 
getResult(I, TabletScanClientService.continueScan_args) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.continueScan
 
getResult(I, TabletScanClientService.getActiveScans_args) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.getActiveScans
 
getResult(I, TabletScanClientService.startMultiScan_args) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startMultiScan
 
getResult(I, TabletScanClientService.startScan_args) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startScan
 
getResult(I, TabletServerClientService.compact_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compact
 
getResult(I, TabletServerClientService.compactionJobFailed_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compactionJobFailed
 
getResult(I, TabletServerClientService.compactionJobFinished_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compactionJobFinished
 
getResult(I, TabletServerClientService.contiuneGetSummaries_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.contiuneGetSummaries
 
getResult(I, TabletServerClientService.fastHalt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.fastHalt
 
getResult(I, TabletServerClientService.flush_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.flush
 
getResult(I, TabletServerClientService.getActiveCompactions_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveCompactions
 
getResult(I, TabletServerClientService.getActiveLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveLogs
 
getResult(I, TabletServerClientService.getCompactionQueueInfo_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getCompactionQueueInfo
 
getResult(I, TabletServerClientService.getHistoricalStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getHistoricalStats
 
getResult(I, TabletServerClientService.getTabletServerStatus_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletServerStatus
 
getResult(I, TabletServerClientService.getTabletStats_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletStats
 
getResult(I, TabletServerClientService.halt_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.halt
 
getResult(I, TabletServerClientService.removeLogs_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.removeLogs
 
getResult(I, TabletServerClientService.reserveCompactionJob_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.reserveCompactionJob
 
getResult(I, TabletServerClientService.startGetSummaries_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummaries
 
getResult(I, TabletServerClientService.startGetSummariesForPartition_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesForPartition
 
getResult(I, TabletServerClientService.startGetSummariesFromFiles_args) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesFromFiles
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticateUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkTableClass
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.createLocalUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getInstanceId
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getSystemProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedNamespaceProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedSystemProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedTableProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.isActive
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.ping
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.fails
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.success
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.throwsError
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.cancel
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionCompleted
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionFailed
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompactionJob
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getRunningCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.updateCompactionStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.cancel
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getActiveCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompaction
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompactionId
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.beginFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.cancelFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.executeFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.finishFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.waitForFateOperation
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getActiveTservers
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getDelegationToken
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getManagerStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.initiateFlush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyNamespaceProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifySystemProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyTableProperties
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeNamespaceProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeSystemProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeTableProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportSplitExtent
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportTabletStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setManagerGoalState
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setNamespaceProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setSystemProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setTableProperty
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdown
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdownTabletServer
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForBalance
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForFlush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.chop
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.flushTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.loadTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.splitTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.unloadTablet
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.applyUpdates
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.closeConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.closeUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.conditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.invalidateConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.loadFiles
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startConditionalUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startUpdate
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.update
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.closeMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.closeScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.continueMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.continueScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.getActiveScans
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startMultiScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startScan
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compact
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compactionJobFailed
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compactionJobFinished
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.contiuneGetSummaries
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.fastHalt
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.flush
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveCompactions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveLogs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getCompactionQueueInfo
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getHistoricalStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletServerStatus
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletStats
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.halt
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.removeLogs
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.reserveCompactionJob
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummaries
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesForPartition
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesFromFiles
 
getResults() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getResults() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
getResultsIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getResultsIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
getResultsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
getResultsSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
getRetryFactory() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getReturn() - Method in interface org.apache.accumulo.core.fate.Repo
 
getReturn(long) - Method in class org.apache.accumulo.core.fate.Fate
 
getRoot(InstanceId) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
 
getRootMetadata(String, ZooCache) - Static method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata
 
getRootTabletLocation() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
getRootTabletLocation() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getRootTabletLocation
 
getRootTabletLocation() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns the location of the tablet server that is serving the root tablet.
getRootTabletLocation() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getRootTabletLocation() - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getRootTabletLocation(ClientContext) - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
getRootTabletLocation(AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getRootTabletLocation(AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getRootTabletLocation_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
getRootTabletLocation_args(ClientService.getRootTabletLocation_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
Performs a deep copy on other.
getRootTabletLocation_call(AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
 
getRootTabletLocation_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
getRootTabletLocation_result(String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
getRootTabletLocation_result(ClientService.getRootTabletLocation_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
Performs a deep copy on other.
getRow() - Method in class org.apache.accumulo.core.data.Key
Gets the row ID as a Text object.
getRow() - Method in class org.apache.accumulo.core.data.Mutation
Gets the row ID for this mutation.
getRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getRow() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getRow() - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
 
getRow(Text) - Method in class org.apache.accumulo.core.data.Key
Writes the row ID into the given Text.
getRowData() - Method in class org.apache.accumulo.core.data.Key
Returns the row ID as a byte sequence.
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.BlipSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ExternalCompactionSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ProblemSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
 
getRowPrefix() - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.ScanServerFileReferenceSection
 
getRowPrefix() - Method in class org.apache.accumulo.core.schema.Section
 
getRowSuffix() - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
getRunning() - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
getRunningCompaction() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompaction
 
getRunningCompaction() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompaction
 
getRunningCompaction(HostAndPort, ClientContext) - Static method in class org.apache.accumulo.core.util.compaction.ExternalCompactionUtil
Get the compaction currently running on the Compactor
getRunningCompaction(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
getRunningCompaction(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.Iface
 
getRunningCompaction(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionJob>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient
 
getRunningCompaction(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionJob>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncIface
 
getRunningCompaction_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getRunningCompaction_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getRunningCompaction_args(CompactorService.getRunningCompaction_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
Performs a deep copy on other.
getRunningCompaction_call(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionJob>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompaction_call
 
getRunningCompaction_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getRunningCompaction_result(CompactorService.getRunningCompaction_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
Performs a deep copy on other.
getRunningCompaction_result(TExternalCompactionJob, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getRunningCompactionId() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompactionId
 
getRunningCompactionId() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompactionId
 
getRunningCompactionId(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
getRunningCompactionId(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.Iface
 
getRunningCompactionId(TInfo, TCredentials, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient
 
getRunningCompactionId(TInfo, TCredentials, AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncIface
 
getRunningCompactionId_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getRunningCompactionId_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getRunningCompactionId_args(CompactorService.getRunningCompactionId_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
Performs a deep copy on other.
getRunningCompactionId_call(TInfo, TCredentials, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompactionId_call
 
getRunningCompactionId_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getRunningCompactionId_result(String, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getRunningCompactionId_result(CompactorService.getRunningCompactionId_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
Performs a deep copy on other.
getRunningCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getRunningCompactions
 
getRunningCompactions() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getRunningCompactions
 
getRunningCompactions() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getRunningCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
getRunningCompactions(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
getRunningCompactions(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
getRunningCompactions(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
getRunningCompactions_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getRunningCompactions_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getRunningCompactions_args(CompactionCoordinatorService.getRunningCompactions_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
Performs a deep copy on other.
getRunningCompactions_call(TInfo, TCredentials, AsyncMethodCallback<TExternalCompactionList>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getRunningCompactions_call
 
getRunningCompactions_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
getRunningCompactions_result(CompactionCoordinatorService.getRunningCompactions_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
Performs a deep copy on other.
getRunningCompactions_result(TExternalCompactionList) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
getRuntime() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
getRunTimeStats() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
Returns timing statistics about running and gathering a batches of data.
getSample(CompactableFile, SamplerConfiguration) - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getSample(SamplerConfigurationImpl) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
getSample(SamplerConfigurationImpl) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getSamplerClassName() - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
getSamplerConfig() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getSamplerConfig() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getSamplerConfiguration() - Method in interface org.apache.accumulo.core.client.ScannerBase
 
getSamplerConfiguration() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getSamplerConfiguration() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
 
getSamplerConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Reads the sampling configuration properties for a table.
getSamplerConfiguration(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getSaslParams() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Retrieve SASL configuration to initiate an RPC connection to a server
getSaslParams() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
getSaslProperties() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
getScanExecutors() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.DispatchParameters
 
getScanExecutors(boolean) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
getScanid() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getScanid() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getScanId() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getScanID() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
getScanID() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
getScanID() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
getScanID() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
getScanInfo() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.DispatchParameters
 
getScannerIterator() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
getScanRate() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getScanRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getScanRate() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getScans() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getScans() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getScanServer(TabletId) - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelections
 
getScanServerFileReferences() - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Get ScanServer references to Tablet files
getScanServers() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Returns the locations of the active scan servers
getScanServers() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getScanServers() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getScanServers() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.InitParameters
 
getScanServerSelector() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getScanType() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
 
getScope() - Method in class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
 
getScope() - Method in interface org.apache.accumulo.core.spi.crypto.CryptoEnvironment
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
getSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
getSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getSec() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
getSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
getSec() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
getSec() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
getSec() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
getSec() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
getSec() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
getSec() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
getSec() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
getSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
getSecond() - Method in class org.apache.accumulo.core.util.Pair
 
getSecret() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
getSecs(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
getSecurityErrorCode() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getSecurityErrorCodes() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getSeen() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getSelector() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getSerializedFormat() - Method in class org.apache.accumulo.core.data.Mutation
Gets the serialization format used to (de)serialize this mutation.
getSerialVersion() - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
getServ() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
getServer() - Method in exception org.apache.accumulo.core.clientImpl.AccumuloServerException
 
getServer() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
getServer() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getServer() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerAttempt
 
getServerAddress() - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
getServerInstance() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getServerLockUUID() - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
getServerName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getServerName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getServerProtocols() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getServersShuttingDown() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getServersShuttingDownIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getServersShuttingDownSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getServerThreadPools() - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
 
getServerUUID(ServiceLockData.ThriftService) - Method in class org.apache.accumulo.core.lock.ServiceLockData
 
getService() - Method in class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptor
 
getService() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatch
 
getService(CryptoEnvironment, Map<String, String>) - Method in interface org.apache.accumulo.core.spi.crypto.CryptoServiceFactory
Return the appropriate CryptoService.
getService(CryptoEnvironment, Map<String, String>) - Method in class org.apache.accumulo.core.spi.crypto.GenericCryptoServiceFactory
 
getService(CryptoEnvironment, Map<String, String>) - Method in class org.apache.accumulo.core.spi.crypto.NoCryptoServiceFactory
 
getService(CryptoEnvironment, Map<String, String>) - Method in class org.apache.accumulo.core.spi.crypto.PerTableCryptoServiceFactory
 
getServicedTableId() - Method in class org.apache.accumulo.core.metadata.MetadataServicer
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.DispatchParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.InitParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.DispatchParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.InitParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.scan.ScanPrioritizer.CreateParameters
 
getServiceEnv() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.InitParameters
 
getServiceEnvironment() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.InitParameters
 
getServiceEnvironment() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getServiceEnvironment() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlannerInitParams
 
getServiceForClient(CryptoEnvironment.Scope, Map<String, String>) - Static method in class org.apache.accumulo.core.crypto.CryptoFactoryLoader
Returns a CryptoService configured for the scope using the properties.
getServiceForClientWithTable(Map<String, String>, Map<String, String>, TableId) - Static method in class org.apache.accumulo.core.crypto.CryptoFactoryLoader
For use by client code, in a Table context.
getServiceForServer(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.crypto.CryptoFactoryLoader
For use by server utilities not associated with a table.
getServiceName() - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
The service name used to identify the Token
getServiceName() - Method in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
getServices() - Method in class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptors
 
getSessID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
getSessID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
getSessID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
getSession() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
getSession() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getSession() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
getSession() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletServerId
 
getSessionId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
getSessionId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getSessionId() - Method in class org.apache.accumulo.core.lock.ServiceLock
 
getSessionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
getSessionId(ZooCache, ServiceLock.ServiceLockPath) - Static method in class org.apache.accumulo.core.lock.ServiceLock
 
getSessionTimeout() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
Returns the requested ZooKeeper client session timeout.
getShownLength() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
 
getSince() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getSingleFactor() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
getSiteConfiguration() - Method in class org.apache.accumulo.core.cli.ConfigOpts
 
getSiteConfiguration() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Retrieve the site configuration (that is set in the server configuration file).
getSiteConfiguration() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getSize() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
getSize() - Method in class org.apache.accumulo.core.data.Key
getSize() - Method in class org.apache.accumulo.core.data.Value
Gets the size of this value.
getSize() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getSizeIterator(AccumuloClient, String, Text, Text) - Method in class org.apache.accumulo.core.util.Merge
 
getSource() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getSources() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getSourcesIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getSourcesSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getSplit() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getSplitCreationTime() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getSplitCreationTime() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getSplitPoint() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
getSplitRatio() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getSplits() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Return Collection of split values.
getSplits() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
getSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
getSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
getSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
getSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
getSsiList() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getSsiList() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getSsiList() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getSsiList() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getSsiList() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getSsiListIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getSsiListSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsio() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getSsio() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getSsio() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getSsio() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getSsio() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getSsioSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getSslParams() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
getStack(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
getStack(long) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Get all operations on a transactions stack.
getStack(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
getStart() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
getStarted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
getStartKey() - Method in class org.apache.accumulo.core.data.Range
Gets the start key, or null if the start is negative infinity.
getStartPos() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer.BlockAppender
 
getStartRow() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getStartRow() - Method in class org.apache.accumulo.core.data.LoadPlan.Destination
 
getStartRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
getStartRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getStartRow() - Method in class org.apache.accumulo.core.summary.Gatherer.RowRange
 
getStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
getStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
getStartTime() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
getState() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getState() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getState() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
getState() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
getState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
getState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getState() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getState(Set<TServerInstance>) - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
getStatistics() - Method in class org.apache.accumulo.core.client.summary.Summary
 
getStats() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get counter statistics for this cache.
getStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
getStats() - Method in class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
getStats() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache
Get the statistics of this cache.
getStats() - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
Finalize the aggregation and return the result.
getStats() - Method in class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
 
getStats() - Method in class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
 
getStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
getStatus() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
getStatus() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
If this method throws an exception, then its possible the mutation is still being actively processed.
getStatus() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getStatus() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
getStatus() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getStatus() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
getStatus() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getStatus(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
getStatus(long) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Get the state of a given transaction.
getStatus(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
getStatus(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getStatus(String, Watcher) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
getStatus(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.Iface
 
getStatus(TInfo, TCredentials, AsyncMethodCallback<GCStatus>) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient
 
getStatus(TInfo, TCredentials, AsyncMethodCallback<GCStatus>) - Method in interface org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncIface
 
getStatus(ReadOnlyTStore<T>, ZooReader, ServiceLock.ServiceLockPath, Set<Long>, EnumSet<ReadOnlyTStore.TStatus>) - Method in class org.apache.accumulo.core.fate.AdminUtil
Get the FATE transaction status and lock information stored in zookeeper, optionally filtered by transaction id and filter status.
getStatus_args() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getStatus_args(TInfo, TCredentials) - 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_call(TInfo, TCredentials, AsyncMethodCallback<GCStatus>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
 
getStatus_result() - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getStatus_result(GCMonitorService.getStatus_result) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
Performs a deep copy on other.
getStatus_result(GCStatus, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getStop() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
getStoredTabletFile() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
getSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
getSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
getSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
getSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
getSuccessIterator() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
getSuccessSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
getSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
getSummaries() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getSummaries() - Method in class org.apache.accumulo.core.summary.SummaryCollection
 
getSummaries(Collection<CompactableFile>, Predicate<SummarizerConfiguration>) - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getSummaries(List<Gatherer.RowRange>) - Method in class org.apache.accumulo.core.summary.SummaryReader
 
getSummariesIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getSummariesSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getSummarizer(SummarizerConfiguration) - Method in class org.apache.accumulo.core.summary.SummarizerFactory
 
getSummarizerConfigs(Iterable<Map.Entry<String, String>>) - Static method in class org.apache.accumulo.core.summary.SummarizerConfigurationUtil
 
getSummarizerConfigs(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.summary.SummarizerConfigurationUtil
 
getSummarizerConfiguration() - Method in class org.apache.accumulo.core.client.summary.Summary
 
getSummarizerPattern() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getSummarizers() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getSummarizersIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getSummarizersSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getSummary() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getSummarySize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
getSupportedAlgorithms() - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Compression
 
getSuspend() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getSymbols() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
getSymbolsIterator() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
getSymbolsSize() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
getSymbolTable() - Method in class org.apache.accumulo.core.clientImpl.CompressedIterators
 
getSyncs() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getSyncs() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getSyncs() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getSysPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getSystemConfiguration() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Retrieve the system-wide, merged view of the system configuration.
getSystemConfiguration() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getSystemProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getSystemProperties
 
getSystemProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getSystemProperties
 
getSystemProperties(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getSystemProperties(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getSystemProperties(TInfo, TCredentials, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getSystemProperties(TInfo, TCredentials, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getSystemProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getSystemProperties_args(ClientService.getSystemProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
Performs a deep copy on other.
getSystemProperties_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getSystemProperties_call(TInfo, TCredentials, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getSystemProperties_call
 
getSystemProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSystemProperties_result(Map<String, String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
getSystemProperties_result(ClientService.getSystemProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
Performs a deep copy on other.
getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getTable() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getTable() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getTable() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getTable() - Method in interface org.apache.accumulo.core.data.TabletId
 
getTable() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
getTable() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
getTable() - Method in interface org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment
 
getTableConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
getTableConfiguration() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableConfiguration
 
getTableConfiguration() - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
getTableConfiguration() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
getTableConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getTableConfiguration(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getTableConfiguration(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getTableConfiguration(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getTableConfiguration_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getTableConfiguration_args(ClientService.getTableConfiguration_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
Performs a deep copy on other.
getTableConfiguration_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getTableConfiguration_call(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableConfiguration_call
 
getTableConfiguration_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getTableConfiguration_result(Map<String, String>, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getTableConfiguration_result(ClientService.getTableConfiguration_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
Performs a deep copy on other.
getTableCustom() - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Users can set arbitrary custom table properties in Accumulo using the prefix table.custom..
getTableCustom() - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getTableCustom(String) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
This method appends the prefix table.custom and gets the property.
getTableCustom(String) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getTableId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InitParameters
 
getTableId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InputParameters
 
getTableId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.InitParameters
 
getTableId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getTableId() - Method in exception org.apache.accumulo.core.client.TableDeletedException
 
getTableId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getTableId() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getTableId() - Method in class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
 
getTableId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
getTableId() - Method in interface org.apache.accumulo.core.gc.Reference
Get the TableId of the reference.
getTableId() - Method in class org.apache.accumulo.core.gc.ReferenceFile
 
getTableId() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Return the table Id associated with this iterator.
getTableId() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile.FileParts
 
getTableId() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
 
getTableId() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getTableId() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
 
getTableId() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher.InitParameters
 
getTableId() - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner.PlanningParameters
 
getTableId() - Method in interface org.apache.accumulo.core.spi.crypto.CryptoEnvironment
If in the TABLE scope, get the tableId.
getTableId() - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher.InitParameters
 
getTableId() - Method in interface org.apache.accumulo.core.spi.scan.ScanInfo
 
getTableId() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
getTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
getTableId(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableId(String) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Lookup table ID in ZK.
getTableID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getTableIdMap() - Method in interface org.apache.accumulo.core.spi.balancer.BalancerEnvironment
Many Accumulo plugins are given table IDs as this is what Accumulo uses internally to identify tables.
getTableIds(ClientContext, NamespaceId) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
 
getTableIdToNameMap() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableInfo() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getTableMap() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getTableMap() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTableMap() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getTableMap() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getTableMap() - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Get the TableMap from the cache.
getTableMapSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTableMapSize() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getTableName() - Method in exception org.apache.accumulo.core.client.TableNotFoundException
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getTableName() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getTableName(TableId) - Method in interface org.apache.accumulo.core.client.PluginEnvironment
Many Accumulo plugins are given table IDs as this is what Accumulo uses internally to identify tables.
getTableName(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableName(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
getTableName(TableId) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
getTableNames(ClientContext, NamespaceId) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
 
getTableNameToIdMap() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableProperties
 
getTableProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableProperties
 
getTableProperties(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Gets per-table properties of a table.
getTableProperties(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getTableProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getTableProperties(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getTableProperties(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getTableProperties(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getTableProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getTableProperties_args(ClientService.getTableProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
Performs a deep copy on other.
getTableProperties_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getTableProperties_call(TInfo, TCredentials, String, AsyncMethodCallback<Map<String, String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableProperties_call
 
getTableProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getTableProperties_result(Map<String, String>, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getTableProperties_result(ClientService.getTableProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
Performs a deep copy on other.
getTables() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
getTables() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getTables() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getTablesIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getTablesIterator() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getTablesSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
getTablesSize() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getTableState(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableState(TableId, boolean) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTableState(TableId, boolean) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Get the current state of the table using the tableid.
getTablet() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getTablet() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getTablet() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getTablet() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getTablet() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Mapping
 
getTablet() - Method in interface org.apache.accumulo.core.data.constraints.Constraint.Environment
Gets the tablet Id of the environment.
getTablet() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getTablet() - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
getTabletCount() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
getTabletCount() - Method in interface org.apache.accumulo.core.spi.balancer.data.TableStatistics
 
getTabletDir() - Method in class org.apache.accumulo.core.gc.ReferenceDirectory
 
getTabletDir() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile.FileParts
 
getTabletDir() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
 
getTabletFile() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
 
getTabletId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.InputParameters
 
getTabletId() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector.SelectionParameters
 
getTabletId() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
getTabletId() - Method in interface org.apache.accumulo.core.spi.balancer.data.TabletStatistics
 
getTabletLocation(TabletId) - Method in interface org.apache.accumulo.core.client.admin.Locations
For any TabletId known to this object, the method will return the tablet server location for that tablet.
getTabletLocations(SortedMap<KeyExtent, String>) - Method in class org.apache.accumulo.core.metadata.MetadataServicer
Populate the provided data structure with the known tablets for the table being serviced
getTablets() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
getTablets() - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector.SelectorParameters
 
getTabletServer() - Method in class org.apache.accumulo.core.client.ConditionalWriter.Result
 
getTabletServer() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
getTabletServerConnection(ClientContext, boolean) - Method in class org.apache.accumulo.core.rpc.clients.ClientServiceThriftClient
 
getTabletServerConnection(ClientContext, boolean) - Method in class org.apache.accumulo.core.rpc.clients.TabletServerThriftClient
 
getTabletServerConnection(ClientContext, boolean) - Method in interface org.apache.accumulo.core.rpc.clients.TServerClient
 
getTabletServerConnection(Logger, ThriftClientTypes<C>, ClientContext, boolean, AtomicBoolean) - Method in interface org.apache.accumulo.core.rpc.clients.TServerClient
 
getTabletServers() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
List the currently active tablet servers participating in the accumulo instance
getTabletServers() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
getTabletServerStatus() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletServerStatus
 
getTabletServerStatus() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletServerStatus
 
getTabletServerStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
getTabletServerStatus(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
getTabletServerStatus(TInfo, TCredentials, AsyncMethodCallback<TabletServerStatus>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
getTabletServerStatus(TInfo, TCredentials, AsyncMethodCallback<TabletServerStatus>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
getTabletServerStatus_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
getTabletServerStatus_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
getTabletServerStatus_args(TabletServerClientService.getTabletServerStatus_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
Performs a deep copy on other.
getTabletServerStatus_call(TInfo, TCredentials, AsyncMethodCallback<TabletServerStatus>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getTabletServerStatus_call
 
getTabletServerStatus_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
getTabletServerStatus_result(TabletServerStatus, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
getTabletServerStatus_result(TabletServerClientService.getTabletServerStatus_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
Performs a deep copy on other.
getTabletState(Set<TServerInstance>) - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getTabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletStats
 
getTabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletStats
 
getTabletStats(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
getTabletStats(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
getTabletStats(TInfo, TCredentials, String, AsyncMethodCallback<List<TabletStats>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
getTabletStats(TInfo, TCredentials, String, AsyncMethodCallback<List<TabletStats>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
getTabletStats_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
getTabletStats_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
getTabletStats_args(TabletServerClientService.getTabletStats_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
Performs a deep copy on other.
getTabletStats_call(TInfo, TCredentials, String, AsyncMethodCallback<List<TabletStats>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getTabletStats_call
 
getTabletStats_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
getTabletStats_result(List<TabletStats>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
getTabletStats_result(TabletServerClientService.getTabletStats_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
Performs a deep copy on other.
getTblNspcPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getTblPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getTerm(byte[]) - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTerm(Key) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
getTerm(Key) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTermEnd() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTermStart() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getTermString() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyValue._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.BulkImportStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.Compacting._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.DeadServer._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.RecoveryStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.DataFileInfo._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration._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.InputFile._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
getThriftFieldId() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
getThriftIdentifier() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getTid() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
getTid() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
getTime() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
getTime() - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
getTime() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
getTimeCreated() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getTimeCreatedFormatted() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getTimedOutSevers() - Method in exception org.apache.accumulo.core.client.TimedOutException
 
getTimeInMillis(String) - Static method in class org.apache.accumulo.core.conf.ConfigurationTypeHelper
Interprets a string specifying a time duration.
getTimeInMillis(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getTimeInMillis(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Gets a property of type PropertyType.TIMEDURATION, interpreting the value properly.
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
 
getTimeout(TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
Returns the setting for how long a scanner will automatically retry when a failure occurs.
getTimeout(TimeUnit) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
getTimesPaused() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getTimestamp() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getTimestamp() - Method in class org.apache.accumulo.core.data.ColumnUpdate
Gets the timestamp for this update.
getTimestamp() - Method in class org.apache.accumulo.core.data.Condition
Gets the timestamp of this condition.
getTimestamp() - Method in class org.apache.accumulo.core.data.Key
Gets the timestamp.
getTimestamp() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
getTimestamp() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
getTimeType() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Retrieve the time type currently configured.
getTimeType(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Return the TimeType for the given table
getTimeType(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
getTimeZone() - Method in class org.apache.accumulo.core.util.format.DateFormatSupplier
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
getTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
getTinfo() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
getTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
getTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
getTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
getTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
getTmfe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
getTmfe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
getTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
getToAuth() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
getToe() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
getToken() - Method in class org.apache.accumulo.core.cli.ClientOpts
 
getToken() - Method in class org.apache.accumulo.core.clientImpl.Credentials
Gets the authentication token.
getToken() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getTokenClassName() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
getTokenLifetime(TimeUnit) - Method in class org.apache.accumulo.core.client.admin.DelegationTokenConfig
The current token lifetime.
getTooLong() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getTooMany() - Method in class org.apache.accumulo.core.client.summary.CounterSummary
 
getTop() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
getTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
getTope() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
getTopKey() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.Combiner
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.DevNull
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
getTopKey() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Returns top key.
getTopKey() - Method in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
getTopKey() - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.Combiner
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.DevNull
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
getTopValue() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Returns top value.
getTopValue() - Method in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
getTopValue() - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
getTotal() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
getTotalFiles() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
getTotalFiles() - Method in class org.apache.accumulo.core.summary.SummaryCollection
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
getTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
getTransactionInfo(long, Fate.TxInfo) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
getTransactionInfo(long, Fate.TxInfo) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Retrieve transaction-specific information.
getTransactionInfo(long, Fate.TxInfo) - Method in class org.apache.accumulo.core.fate.ZooStore
 
getTransactions() - Method in class org.apache.accumulo.core.fate.AdminUtil.FateStatus
 
getTransactionStatus(ReadOnlyTStore<T>, Set<Long>, EnumSet<ReadOnlyTStore.TStatus>) - Method in class org.apache.accumulo.core.fate.AdminUtil
Returns a list of the FATE transactions, optionally filtered by transaction id and status.
getTransport(HostAndPort, long, ClientContext) - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportPool
 
getTransport(TTransport) - Method in class org.apache.accumulo.core.rpc.UGIAssumingTransportFactory
 
getTransportPool() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTransportPoolMaxAgeMillis() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getTrustStorePass() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getTrustStorePath() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getTrustStoreType() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getTs() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getTServerInfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTServerInfoIterator() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTServerInfoSize() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getTserverLocation() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocation
 
getTserverLock() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
getTserverSession() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocation
 
getTsnpe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
getTsnpe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
getTsnpe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
getTsnpe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
getTtl() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
getTTransportParams() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
getTxid() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getTxName() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getType() - Method in interface org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost
 
getType() - Method in class org.apache.accumulo.core.client.admin.ActiveCompaction
 
getType() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getType() - Method in class org.apache.accumulo.core.clientImpl.ActiveCompactionImpl
 
getType() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getType() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
getType() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
getType() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getType() - Method in enum org.apache.accumulo.core.conf.Property
Gets the type of this property.
getType() - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
getType() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
getType() - Method in class org.apache.accumulo.core.security.ColumnVisibility.Node
 
getType() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
getType(char) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataTime
Converts timetypes to data codes used in the table data implementation
getUnassignedTablets() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
getUniqueID() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
getUnknownExceptions() - Method in exception org.apache.accumulo.core.client.MutationsRejectedException
 
getUnnamedOptionDescriptions() - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
getUpdateCount() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Each time configuration changes, this counter should increase.
getUpdateCount() - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
getUpdateCount() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache
Returns a monotonically increasing count of the number of time the cache was updated.
getUpdatedLoadMapping(String, TableId, BulkSerialize.Input) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkSerialize
Read in both maps and change all the file names in the mapping to the new names.
getUpdateID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
getUpdateID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
getUpdates() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getUpdates() - Method in class org.apache.accumulo.core.data.Mutation
Gets the modifications and deletions in this mutation.
getUpdates() - Method in class org.apache.accumulo.core.util.compaction.RunningCompaction
 
getUpdates() - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
 
getUpdatesSize() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
getUri() - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactableFile
 
getUri() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
getUsage() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
getUsage() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
getUser() - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
getUser() - Method in class org.apache.accumulo.core.client.admin.ActiveScan
 
getUser() - Method in class org.apache.accumulo.core.clientImpl.ActiveScanImpl
 
getUser() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
getUser() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
getUser() - Method in interface org.apache.accumulo.core.data.constraints.Constraint.Environment
Gets the user within the environment.
getUser() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
getUserAuthorizations() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
getUserAuthorizations() - Constructor for class org.apache.accumulo.core.clientImpl.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.clientImpl.SecurityOperationsImpl
 
getUserAuthorizations(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getUserAuthorizations(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getUserAuthorizations(TInfo, TCredentials, String, AsyncMethodCallback<List<ByteBuffer>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getUserAuthorizations(TInfo, TCredentials, String, AsyncMethodCallback<List<ByteBuffer>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getUserAuthorizations_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getUserAuthorizations_args(ClientService.getUserAuthorizations_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
Performs a deep copy on other.
getUserAuthorizations_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
getUserAuthorizations_call(TInfo, TCredentials, String, AsyncMethodCallback<List<ByteBuffer>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
 
getUserAuthorizations_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getUserAuthorizations_result(List<ByteBuffer>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
getUserAuthorizations_result(ClientService.getUserAuthorizations_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
Performs a deep copy on other.
getUserCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
getUUID() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Retrieve a unique identifier for this tablet that is useful for logging, without revealing the contents of the end row and previous end row.
getUUID() - Method in class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptor
 
getVal() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
getValidExtensions() - Static method in class org.apache.accumulo.core.file.FileOperations
 
getValue() - Method in enum org.apache.accumulo.core.clientImpl.thrift.ConfigurationType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.compaction.thrift.TCompactionState
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.dataImpl.thrift.TCMStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
getValue() - Method in enum org.apache.accumulo.core.manager.thrift.BulkImportState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.manager.thrift.FateOperation
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
getValue() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
getValue() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
getValue() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerGoalState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.manager.thrift.ManagerState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.manager.thrift.TabletLoadState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
getValue() - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
getValue() - Method in enum org.apache.accumulo.core.tablet.thrift.TUnloadTabletGoal
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.tabletingest.thrift.TDurability
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.tabletscan.thrift.ScanState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.tabletscan.thrift.ScanType
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.TCompactionKind
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
getValue(Configuration, String) - Static method in class org.apache.accumulo.core.conf.HadoopCredentialProvider
Attempt to extract the password from any configured CredentialProviders for the given alias.
getValues() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getValuesIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getValuesSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
getVectorSize() - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
getVersion() - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
getVersion() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
getVersion() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
getVersion() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
getVersion() - Method in interface org.apache.accumulo.core.spi.balancer.data.TServerStatus
 
getVersionedNamespaceProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedNamespaceProperties
 
getVersionedNamespaceProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedNamespaceProperties
 
getVersionedNamespaceProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getVersionedNamespaceProperties(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getVersionedNamespaceProperties(TInfo, TCredentials, String, AsyncMethodCallback<TVersionedProperties>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getVersionedNamespaceProperties(TInfo, TCredentials, String, AsyncMethodCallback<TVersionedProperties>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getVersionedNamespaceProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getVersionedNamespaceProperties_args(ClientService.getVersionedNamespaceProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
Performs a deep copy on other.
getVersionedNamespaceProperties_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
getVersionedNamespaceProperties_call(TInfo, TCredentials, String, AsyncMethodCallback<TVersionedProperties>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedNamespaceProperties_call
 
getVersionedNamespaceProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getVersionedNamespaceProperties_result(ClientService.getVersionedNamespaceProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
Performs a deep copy on other.
getVersionedNamespaceProperties_result(TVersionedProperties, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
getVersionedSystemProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedSystemProperties
 
getVersionedSystemProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedSystemProperties
 
getVersionedSystemProperties(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getVersionedSystemProperties(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getVersionedSystemProperties(TInfo, TCredentials, AsyncMethodCallback<TVersionedProperties>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getVersionedSystemProperties(TInfo, TCredentials, AsyncMethodCallback<TVersionedProperties>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getVersionedSystemProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
getVersionedSystemProperties_args(ClientService.getVersionedSystemProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
Performs a deep copy on other.
getVersionedSystemProperties_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
getVersionedSystemProperties_call(TInfo, TCredentials, AsyncMethodCallback<TVersionedProperties>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedSystemProperties_call
 
getVersionedSystemProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
getVersionedSystemProperties_result(ClientService.getVersionedSystemProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
Performs a deep copy on other.
getVersionedSystemProperties_result(TVersionedProperties, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
getVersionedTableProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedTableProperties
 
getVersionedTableProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedTableProperties
 
getVersionedTableProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getVersionedTableProperties(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getVersionedTableProperties(TInfo, TCredentials, String, AsyncMethodCallback<TVersionedProperties>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getVersionedTableProperties(TInfo, TCredentials, String, AsyncMethodCallback<TVersionedProperties>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getVersionedTableProperties_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getVersionedTableProperties_args(ClientService.getVersionedTableProperties_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
Performs a deep copy on other.
getVersionedTableProperties_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
getVersionedTableProperties_call(TInfo, TCredentials, String, AsyncMethodCallback<TVersionedProperties>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedTableProperties_call
 
getVersionedTableProperties_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getVersionedTableProperties_result(ClientService.getVersionedTableProperties_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
Performs a deep copy on other.
getVersionedTableProperties_result(TVersionedProperties, ThriftTableOperationException, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
getViolationCode() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getViolationCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
getViolationDescription() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
getViolationDescription() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
getViolationDescription(short) - Method in interface org.apache.accumulo.core.data.constraints.Constraint
Gets a short, one-sentence description of what a given violation code means.
getViolationDescription(short) - Method in class org.apache.accumulo.core.data.constraints.DefaultKeySizeConstraint
 
getViolationDescription(short) - Method in class org.apache.accumulo.core.data.constraints.NoDeleteConstraint
 
getViolationDescription(short) - Method in class org.apache.accumulo.core.data.constraints.VisibilityConstraint
 
getViolationSummaries() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getViolationSummaries() - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
getViolationSummariesIterator() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getViolationSummariesIterator() - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
getViolationSummariesSize() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
getViolationSummariesSize() - Method in exception org.apache.accumulo.core.tabletingest.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
 
getVisLG() - Method in class org.apache.accumulo.core.file.rfile.VisibilityMetric
 
getVisLGPer() - Method in class org.apache.accumulo.core.file.rfile.VisibilityMetric
 
getVolume() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile.FileParts
 
getVolume() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
 
getVolumeUris(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.volume.VolumeConfiguration
 
getVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
getVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
getVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
getWait() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
getWaitFactor() - Method in class org.apache.accumulo.core.util.Retry
 
getWaitingLocks() - Method in class org.apache.accumulo.core.fate.AdminUtil.TransactionStatus
 
getWaitTime() - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
The amount of time to wait between balancing.
getWaitTime() - Method in class org.apache.accumulo.core.spi.balancer.RegexGroupBalancer
 
getWatching() - Method in class org.apache.accumulo.core.lock.ServiceLock
 
getWithPrefix(String) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Returns all properties with a given prefix
getWithPrefix(String) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
getWrapped() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
getZkDigestAuthId(String) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
Get the ZooKeeper digest based on the instance secret that is used within ZooKeeper for authentication.
getZooCache() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getZooCache(String, int) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCacheFactory
Gets a ZooCache.
getZooKeeper() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
getZooKeeper() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
 
getZooKeeperRoot() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
getZooKeepers() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
getZooKeepers() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getZooKeepers
 
getZooKeepers() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns a comma-separated list of zookeeper servers the instance is using.
getZooKeepers() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getZooKeepers() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getZooKeepers() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
getZooKeepers() - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
getZooKeepers(AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
getZooKeepers(AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
getZooKeepers_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
getZooKeepers_args(ClientService.getZooKeepers_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
Performs a deep copy on other.
getZooKeepers_call(AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getZooKeepers_call
 
getZooKeepers_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
getZooKeepers_result(String) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
getZooKeepers_result(ClientService.getZooKeepers_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
Performs a deep copy on other.
getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Returns the zookeeper connection timeout.
getZooKeepersSessionTimeOut() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
getZooKeepersSessionTimeOut() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
getZooReader() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
goal - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
GOAL - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args._Fields
 
GOAL_STATE - org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
goalState - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
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.security.SecurityErrorCode
 
GRANT_INVALID - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
grantNamespacePermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
grantNamespacePermission() - Constructor for class org.apache.accumulo.core.clientImpl.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.clientImpl.SecurityOperationsImpl
 
grantNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
grantNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
grantNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
grantNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
grantNamespacePermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
grantNamespacePermission_args(ClientService.grantNamespacePermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
Performs a deep copy on other.
grantNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
grantNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
 
grantNamespacePermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
grantNamespacePermission_result(ClientService.grantNamespacePermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
Performs a deep copy on other.
grantNamespacePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
grantSystemPermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
grantSystemPermission() - Constructor for class org.apache.accumulo.core.clientImpl.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.clientImpl.SecurityOperationsImpl
 
grantSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
grantSystemPermission(TInfo, TCredentials, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
grantSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
grantSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
grantSystemPermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
grantSystemPermission_args(ClientService.grantSystemPermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
Performs a deep copy on other.
grantSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
grantSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantSystemPermission_call
 
grantSystemPermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
grantSystemPermission_result(ClientService.grantSystemPermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
Performs a deep copy on other.
grantSystemPermission_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
grantTablePermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
grantTablePermission() - Constructor for class org.apache.accumulo.core.clientImpl.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.clientImpl.SecurityOperationsImpl
 
grantTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
grantTablePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
grantTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
grantTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
grantTablePermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
grantTablePermission_args(ClientService.grantTablePermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
Performs a deep copy on other.
grantTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
grantTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantTablePermission_call
 
grantTablePermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
grantTablePermission_result(ClientService.grantTablePermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
Performs a deep copy on other.
grantTablePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
GrepIterator - Class in org.apache.accumulo.core.iterators.user
This iterator provides exact string matching.
GrepIterator() - Constructor for class org.apache.accumulo.core.iterators.user.GrepIterator
 
GroupBalancer - Class in org.apache.accumulo.core.spi.balancer
A balancer that evenly spreads groups of tablets across all tablet server.
GroupBalancer(TableId) - Constructor for class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
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.
GSON - Static variable in class org.apache.accumulo.core.util.LazySingletons
A Gson instance constructed with defaults.
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 - Class in org.apache.accumulo.core.spi.file.rfile.compression
 
Gz() - Constructor for class org.apache.accumulo.core.spi.file.rfile.compression.Gz
 

H

HadoopCredentialProvider - Class in org.apache.accumulo.core.conf
Shim around Hadoop's CredentialProviderFactory provided by hadoop-common.
HadoopCredentialProvider() - Constructor for class org.apache.accumulo.core.conf.HadoopCredentialProvider
 
halt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.halt
 
halt() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.halt
 
halt(int, Runnable) - Static method in class org.apache.accumulo.core.util.Halt
 
halt(String) - Static method in class org.apache.accumulo.core.util.Halt
 
halt(String, int) - Static method in class org.apache.accumulo.core.util.Halt
 
halt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
halt(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
halt(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
halt(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
Halt - Class in org.apache.accumulo.core.util
 
Halt() - Constructor for class org.apache.accumulo.core.util.Halt
 
halt_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
halt_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
halt_args(TabletServerClientService.halt_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
Performs a deep copy on other.
halt_call(TInfo, TCredentials, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.halt_call
 
halt_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
halt_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
halt_result(TabletServerClientService.halt_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.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.dataImpl.thrift.TCondition._Fields
 
hasChopped() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
hasColumns(Key) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
hasCurrent() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
hasCurrent() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
hasFuture() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
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.DelegationTokenConfig
 
hashCode() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
hashCode() - Method in class org.apache.accumulo.core.client.admin.PluginConfig
 
hashCode() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
hashCode() - Method in class org.apache.accumulo.core.client.IteratorSetting
 
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.client.summary.SummarizerConfiguration
Hashes the classname and options to create a hashcode.
hashCode() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.Credentials
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocation
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
hashCode() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
hashCode() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
hashCode() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
hashCode() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
hashCode() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
hashCode() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
hashCode() - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
hashCode() - Method in class org.apache.accumulo.core.data.AbstractId
 
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.Key
 
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.Value
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
hashCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
hashCode() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.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.ReferenceFile
 
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.OrIterator.TermSource
 
hashCode() - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnUtil.ColFamHashKey
 
hashCode() - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnUtil.ColHashKey
 
hashCode() - Method in class org.apache.accumulo.core.lock.ServiceLockData
 
hashCode() - Method in class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptor
 
hashCode() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
hashCode() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
hashCode() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
hashCode() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
hashCode() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
hashCode() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
hashCode() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
hashCode() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
 
hashCode() - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
hashCode() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
hashCode() - Method in class org.apache.accumulo.core.metadata.schema.MetadataTime
 
hashCode() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
hashCode() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
 
hashCode() - Method in class org.apache.accumulo.core.metadata.SuspendingTServer
 
hashCode() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
hashCode() - Method in class org.apache.accumulo.core.metadata.UnreferencedTabletFile
 
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.securityImpl.thrift.TAuthenticationKey
 
hashCode() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
hashCode() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
hashCode() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
hashCode() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
hashCode() - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
hashCode() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
hashCode() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
hashCode() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
hashCode() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
hashCode() - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
hashCode() - Method in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
hashCode() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
hashCode() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
hashCode() - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
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.InputFile
 
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.TabletServerClientService.compact_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
hashCode() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
hashCode() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
hashCode() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
hashCode() - Method in class org.apache.accumulo.core.util.compaction.CompactionServicesConfig
 
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.volume.VolumeImpl
 
hashType - Variable in class org.apache.accumulo.core.bloomfilter.Filter
Type of hashing function to use.
hasInfiniteRetries() - Method in class org.apache.accumulo.core.util.Retry
 
hasNamespacePermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
hasNamespacePermission() - Constructor for class org.apache.accumulo.core.clientImpl.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.clientImpl.SecurityOperationsImpl
 
hasNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
hasNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
hasNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
hasNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
hasNamespacePermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
hasNamespacePermission_args(ClientService.hasNamespacePermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
Performs a deep copy on other.
hasNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
hasNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
 
hasNamespacePermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
hasNamespacePermission_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
hasNamespacePermission_result(ClientService.hasNamespacePermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
Performs a deep copy on other.
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.clientImpl.bulk.LoadMappingIterator
 
hasNext() - Method in class org.apache.accumulo.core.clientImpl.ScannerIterator
 
hasNext() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReaderIterator
 
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.metadata.schema.LinkingIterator
 
hasNext() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
hasNext() - Method in class org.apache.accumulo.core.util.PeekingIterator
 
hasPrevious() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
hasRetried() - Method in class org.apache.accumulo.core.util.Retry
 
hasSuspend() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
hasSystemPermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
hasSystemPermission() - Constructor for class org.apache.accumulo.core.clientImpl.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.clientImpl.SecurityOperationsImpl
 
hasSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
hasSystemPermission(TInfo, TCredentials, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
hasSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
hasSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
hasSystemPermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
hasSystemPermission_args(ClientService.hasSystemPermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
Performs a deep copy on other.
hasSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
hasSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasSystemPermission_call
 
hasSystemPermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
hasSystemPermission_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
hasSystemPermission_result(ClientService.hasSystemPermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
Performs a deep copy on other.
hasTablePermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
hasTablePermission() - Constructor for class org.apache.accumulo.core.clientImpl.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.clientImpl.SecurityOperationsImpl
 
hasTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
hasTablePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
hasTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
hasTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
hasTablePermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
hasTablePermission_args(ClientService.hasTablePermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
Performs a deep copy on other.
hasTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
hasTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasTablePermission_call
 
hasTablePermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
hasTablePermission_result(boolean, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
hasTablePermission_result(ClientService.hasTablePermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
Performs a deep copy on other.
hasTimestamp - Variable in class org.apache.accumulo.core.dataImpl.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.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 class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
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.SynchronizedServerFilter
 
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
 
hasTop() - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
hasTop() - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
hasTop() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
hasTop() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
hasTop() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
hasTop() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
hasTop() - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
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.manager.thrift.ManagerState
 
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.
headers - Variable in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
HEADERS - org.apache.accumulo.core.clientImpl.thrift.TInfo._Fields
 
HeapIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
Constructs a PriorityQueue of multiple SortedKeyValueIterators.
HeapIterator() - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
HeapIterator(int) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlockQueue
Total size of all elements in this queue.
heapSize() - Method in interface org.apache.accumulo.core.file.blockfile.cache.lru.HeapSize
 
heapSize() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
HeapSize - Interface in org.apache.accumulo.core.file.blockfile.cache.lru
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
 
HintScanPrioritizer - Class in org.apache.accumulo.core.spi.scan
When configured for a scan executor, this prioritizer allows scanners to set priorities as integers.
HintScanPrioritizer() - Constructor for class org.apache.accumulo.core.spi.scan.HintScanPrioritizer
 
hit() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
hitCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
hitCount() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache.Stats
Returns the number of lookups that have returned a cached value.
HOLD_TIME - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
holdTime - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
HOST_BALANCER_OOB_CHECK_KEY - Static variable in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
HOST_BALANCER_OUTSTANDING_MIGRATIONS_KEY - Static variable in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
HOST_BALANCER_PREFIX - Static variable in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
HOST_BALANCER_REGEX_MAX_MIGRATIONS_KEY - Static variable in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
HOST_BALANCER_REGEX_USING_IPS_KEY - Static variable in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
HostAndPortComparator - Class in org.apache.accumulo.core.util
 
HostAndPortComparator() - Constructor for class org.apache.accumulo.core.util.HostAndPortComparator
 
HOSTED - org.apache.accumulo.core.metadata.TabletState
 
HOSTLIST - org.apache.accumulo.core.conf.PropertyType
 
HostRegexTableLoadBalancer - Class in org.apache.accumulo.core.spi.balancer
This balancer creates groups of tablet servers using user-provided regular expressions over the tablet server hostnames.
HostRegexTableLoadBalancer() - Constructor for class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
HUMAN_READABLE_FORMAT - Static variable in class org.apache.accumulo.core.util.format.DateFormatSupplier
 

I

id - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
id() - Method in class org.apache.accumulo.core.clientImpl.Namespace
 
ID - org.apache.accumulo.core.dataImpl.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
 
identifier - Variable in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
IDENTIFIER - org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
 
IdentityCodec - Class in org.apache.accumulo.core.file.rfile.bcfile
 
IdentityCodec() - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec
 
IdentityCodec.IdentityCompressionInputStream - Class in org.apache.accumulo.core.file.rfile.bcfile
 
IdentityCodec.IdentityCompressionOutputStream - Class in org.apache.accumulo.core.file.rfile.bcfile
 
IdentityCodec.IdentityCompressor - Class in org.apache.accumulo.core.file.rfile.bcfile
 
IdentityCodec.IdentityDecompressor - Class in org.apache.accumulo.core.file.rfile.bcfile
 
IdentityCompressionInputStream(InputStream) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionInputStream
 
IdentityCompressionOutputStream(OutputStream) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionOutputStream
 
IdentityCompressor() - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
IdentityDecompressor() - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
IDLE - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
idle compaction
IDLE - org.apache.accumulo.core.client.admin.ScanState
 
IDLE - org.apache.accumulo.core.tabletscan.thrift.ScanState
 
IDLE - org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
 
IDLE_TIME - org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
IdleRatioScanPrioritizer - Class in org.apache.accumulo.core.spi.scan
Prioritize scans based on the ratio of runTime/idleTime.
IdleRatioScanPrioritizer() - Constructor for class org.apache.accumulo.core.spi.scan.IdleRatioScanPrioritizer
 
idleTime - Variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
IGNORED - org.apache.accumulo.core.dataImpl.thrift.TCMStatus
 
ignoreEmptyDir(boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations.ImportOptions
Ignores empty bulk import source directory, rather than throwing an IllegalArgumentException.
ignoreEmptyDir(boolean) - Method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
IMMEDIATE - org.apache.accumulo.core.client.ScannerBase.ConsistencyLevel
 
IMMEDIATE - org.apache.accumulo.core.metadata.schema.Ample.ReadConsistency
Read data in a way that is slower, but should always yield the latest data.
IMPORT - org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
IMPORT_MAPPINGS_FILE - Static variable in class org.apache.accumulo.core.Constants
 
ImportConfiguration - Interface in org.apache.accumulo.core.client.admin
A configuration object that can be used with TableOperations.importTable(String, Set, ImportConfiguration)
ImportConfiguration.Builder - Interface in org.apache.accumulo.core.client.admin
A ImportConfiguration builder
ImportConfigurationImpl - Class in org.apache.accumulo.core.clientImpl
 
ImportConfigurationImpl() - Constructor for class org.apache.accumulo.core.clientImpl.ImportConfigurationImpl
 
importDirectory(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Bulk import the files in a directory into a table.
importDirectory(String) - Method in class org.apache.accumulo.core.clientImpl.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, Set<String>, ImportConfiguration) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Imports a table exported via TableOperations.exportTable(String, String) and then copied via hadoop distcp.
importTable(String, Set<String>, ImportConfiguration) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
IN_PROGRESS - org.apache.accumulo.core.compaction.thrift.TCompactionState
 
IN_PROGRESS - org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Transaction that is executing
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.file.FileOperations.FileOptions
 
inclusive - Variable in class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
increment(KT, long) - Method in class org.apache.accumulo.core.util.MapCounter
 
incrementBy(long, TimeUnit) - Method in interface org.apache.accumulo.core.util.Retry.NeedsTimeIncrement
 
INDEX - org.apache.accumulo.core.spi.cache.CacheType
 
INDEX_CACHE_HITS - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
INDEX_CACHE_REQUEST - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
indexCacheHits - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
indexCacheRequest - Variable in class org.apache.accumulo.core.manager.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
 
IndexReaderBuilder() - Constructor for class org.apache.accumulo.core.file.FileOperations.IndexReaderBuilder
 
indexWeightChanged() - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
indexWeightChanged() - Method in interface org.apache.accumulo.core.spi.cache.CacheEntry
The object optionally stored by CacheEntry.getIndex(Supplier) is a mutable object.
INFINITE_START_KEY - org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
INFINITE_STOP_KEY - org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
infiniteRetries() - Method in interface org.apache.accumulo.core.util.Retry.NeedsRetries
 
infiniteStartKey - Variable in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
infiniteStopKey - Variable in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
INGEST_BYTE_RATE - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
INGEST_RATE - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
INGEST_RATE - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
ingestByteRate - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
ingestRate - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
ingestRate - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
INGNORE_DELETES_DEFAULT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
 
INGNORE_DELETES_OPT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
A configuration option to determine if delete keys should be counted.
init(Map<String, String>) - Method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
init(Map<String, String>) - Method in interface org.apache.accumulo.core.spi.crypto.CryptoService
Initialize CryptoService.
init(Map<String, String>) - Method in class org.apache.accumulo.core.spi.crypto.NoCryptoService
 
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(CompactionConfigurer.InitParameters) - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer
 
init(CompactionConfigurer.InitParameters) - Method in class org.apache.accumulo.core.client.admin.compaction.CompressionConfigurer
 
init(CompactionConfigurer.InitParameters) - Method in class org.apache.accumulo.core.compaction.ShellCompactCommandConfigurer
 
init(CompactionSelector.InitParameters) - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector
 
init(CompactionSelector.InitParameters) - Method in class org.apache.accumulo.core.client.admin.compaction.TooManyDeletesSelector
 
init(CompactionSelector.InitParameters) - Method in class org.apache.accumulo.core.compaction.ShellCompactCommandSelector
 
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 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(AuthenticationToken.Properties) - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
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.iteratorsImpl.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.rfile.RFile.Reader
 
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.ServerFilter
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
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
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.CountingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.MultiIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
init(SortedKeyValueIterator<Key, Value>, Map<String, String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
init(BalancerEnvironment) - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
init(BalancerEnvironment) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
init(BalancerEnvironment) - Method in class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
init(BalancerEnvironment) - Method in class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
init(BalancerEnvironment) - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer
Initialize the TabletBalancer.
init(ContextClassLoaderEnvironment) - Method in interface org.apache.accumulo.core.spi.common.ContextClassLoaderFactory
Pass the service environment to allow for additional class loader configuration
init(CompactionDispatcher.InitParameters) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatcher
This method is called once after a CompactionDispatcher is instantiated.
init(CompactionDispatcher.InitParameters) - Method in class org.apache.accumulo.core.spi.compaction.SimpleCompactionDispatcher
 
init(CompactionPlanner.InitParameters) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner
 
init(CompactionPlanner.InitParameters) - Method in class org.apache.accumulo.core.spi.compaction.DefaultCompactionPlanner
 
init(ScanDispatcher.InitParameters) - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatcher
This method is called once after a ScanDispatcher is instantiated.
init(ScanDispatcher.InitParameters) - Method in class org.apache.accumulo.core.spi.scan.SimpleScanDispatcher
 
init(ScanServerSelector.InitParameters) - Method in class org.apache.accumulo.core.spi.scan.ConfigurableScanServerSelector
 
init(ScanServerSelector.InitParameters) - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector
This method is called once after a ScanServerSelector is instantiated.
INIT - org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment.Scope
 
initContextFactory(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.classloader.ClassLoaderUtil
Initialize the ContextClassLoaderFactory
INITIAL - org.apache.accumulo.core.manager.thrift.BulkImportState
 
INITIAL - org.apache.accumulo.core.manager.thrift.ManagerState
 
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(Iterator<E>) - Method in class org.apache.accumulo.core.util.PeekingIterator
Initializes this iterator, to be used with PeekingIterator().
initializeMetrics(AccumuloConfiguration, String, HostAndPort) - Static method in class org.apache.accumulo.core.metrics.MetricsUtil
 
initializeProducers(MetricsProducer...) - Static method in class org.apache.accumulo.core.metrics.MetricsUtil
 
initializeTracer(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
InitialMultiScan - Class in org.apache.accumulo.core.dataImpl.thrift
 
InitialMultiScan() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
InitialMultiScan(long, MultiScanResult) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
InitialMultiScan(InitialMultiScan) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
Performs a deep copy on other.
InitialMultiScan._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InitialScan - Class in org.apache.accumulo.core.dataImpl.thrift
 
InitialScan() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
InitialScan(long, ScanResult) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
InitialScan(InitialScan) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.InitialScan
Performs a deep copy on other.
InitialScan._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InitialTableState - Enum in org.apache.accumulo.core.client.admin
Creation mode for table creation.
initiateFlush() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.initiateFlush
 
initiateFlush() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.initiateFlush
 
initiateFlush(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
initiateFlush(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
initiateFlush(TInfo, TCredentials, String, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
initiateFlush(TInfo, TCredentials, String, AsyncMethodCallback<Long>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
initiateFlush_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
initiateFlush_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
initiateFlush_args(ManagerClientService.initiateFlush_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
Performs a deep copy on other.
initiateFlush_call(TInfo, TCredentials, String, AsyncMethodCallback<Long>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.initiateFlush_call
 
initiateFlush_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
initiateFlush_result(long, ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
initiateFlush_result(ManagerClientService.initiateFlush_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
Performs a deep copy on other.
input(InputStream, String) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
INPUT_FILES - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
InputFile - Class in org.apache.accumulo.core.tabletserver.thrift
 
InputFile() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
InputFile(String, long, long, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
InputFile(InputFile) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.InputFile
Performs a deep copy on other.
InputFile._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.
inputFiles - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
insert() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
New file was written to metadata so return a StoredTabletFile
INSTANCE - Static variable in class org.apache.accumulo.core.util.ratelimit.NullRateLimiter
 
INSTANCE_CRYPTO_FACTORY - org.apache.accumulo.core.conf.Property
 
INSTANCE_CRYPTO_PREFIX - org.apache.accumulo.core.conf.Property
 
INSTANCE_CRYPTO_SENSITIVE_PREFIX - org.apache.accumulo.core.conf.Property
 
INSTANCE_ID - org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
INSTANCE_ID - org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
 
INSTANCE_ID_DIR - Static variable in class org.apache.accumulo.core.Constants
 
INSTANCE_NAME - org.apache.accumulo.core.conf.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.conf.Property
 
INSTANCE_RPC_SSL_CLIENT_AUTH - org.apache.accumulo.core.conf.Property
 
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_VOLUME_CONFIG_PREFIX - org.apache.accumulo.core.conf.Property
 
INSTANCE_VOLUMES - org.apache.accumulo.core.conf.Property
 
INSTANCE_VOLUMES_REPLACEMENTS - org.apache.accumulo.core.conf.Property
 
INSTANCE_VOLUMES_UPGRADE_RELATIVE - org.apache.accumulo.core.conf.Property
 
INSTANCE_ZK_HOST - org.apache.accumulo.core.conf.Property
 
INSTANCE_ZK_TIMEOUT - org.apache.accumulo.core.conf.Property
 
INSTANCE_ZOOKEEPERS - org.apache.accumulo.core.conf.ClientProperty
 
INSTANCE_ZOOKEEPERS_TIMEOUT - org.apache.accumulo.core.conf.ClientProperty
 
instanceId - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
instanceId - Variable in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
InstanceId - Class in org.apache.accumulo.core.data
A strongly typed representation of an Accumulo instance ID.
instanceOperations() - Method in interface org.apache.accumulo.core.client.AccumuloClient
Retrieves an InstanceOperations object to modify instance configuration.
instanceOperations() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
InstanceOperations - Interface in org.apache.accumulo.core.client.admin
 
InstanceOperationsImpl - Class in org.apache.accumulo.core.clientImpl
Provides a class for administering the accumulo instance
InstanceOperationsImpl(ClientContext) - Constructor for class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
instantiate(String, Class<T>) - Method in interface org.apache.accumulo.core.client.PluginEnvironment
Instantiate a class using Accumulo's system classloader.
instantiate(String, Class<T>) - Method in class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
instantiate(TableId, String, Class<T>) - Method in interface org.apache.accumulo.core.client.PluginEnvironment
Instantiate a class using Accumulo's per table classloader.
instantiate(TableId, String, Class<T>) - Method in class org.apache.accumulo.core.clientImpl.ClientServiceEnvironmentImpl
 
INSUFFICIENT_PROPERTIES - org.apache.accumulo.core.client.security.SecurityErrorCode
 
INSUFFICIENT_PROPERTIES - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
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.clientImpl.thrift.ClientService.checkClass_args._Fields
 
INTERFACE_MATCH - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
INTERFACE_MATCH - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
interfaceMatch - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
interfaceMatch - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
interfaceMatch - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
intern(T) - Method in class org.apache.accumulo.core.util.Interner
 
internalId(CompactionServiceId, String) - Static method in class org.apache.accumulo.core.util.compaction.CompactionExecutorIdImpl
 
Interner<T> - Class in org.apache.accumulo.core.util
A utility that mimics String.intern() for any immutable object type (including String).
Interner() - Constructor for class org.apache.accumulo.core.util.Interner
 
InterruptibleIterator - Interface in org.apache.accumulo.core.iteratorsImpl.system
Allows an iterator to be interrupted.
IntersectingIterator - Class in org.apache.accumulo.core.iterators.user
This iterator facilitates document-partitioned indexing.
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.security.SecurityErrorCode
 
INVALID_INSTANCEID - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
INVALID_NAME - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
INVALID_TOKEN - org.apache.accumulo.core.client.security.SecurityErrorCode
 
INVALID_TOKEN - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
invalidateCache() - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
invalidateCache() - Method in class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
invalidateCache() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator
Invalidate entire cache
invalidateCache() - Method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
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.clientImpl.TabletLocatorImpl.TabletServerLockChecker
 
invalidateCache(String) - Method in class org.apache.accumulo.core.clientImpl.ZookeeperLockChecker
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator
 
invalidateCache(Collection<KeyExtent>) - Method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
invalidateCache(ClientContext, String) - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
invalidateCache(ClientContext, String) - Method in class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
invalidateCache(ClientContext, String) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator
Invalidate all metadata entries that point to server
invalidateCache(ClientContext, String) - Method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator
 
invalidateCache(KeyExtent) - Method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
invalidateConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.invalidateConditionalUpdate
 
invalidateConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.invalidateConditionalUpdate
 
invalidateConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
invalidateConditionalUpdate(TInfo, long) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Iface
 
invalidateConditionalUpdate(TInfo, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient
 
invalidateConditionalUpdate(TInfo, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncIface
 
invalidateConditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
invalidateConditionalUpdate_args(TInfo, long) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
invalidateConditionalUpdate_args(TabletIngestClientService.invalidateConditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
Performs a deep copy on other.
invalidateConditionalUpdate_call(TInfo, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.invalidateConditionalUpdate_call
 
invalidateConditionalUpdate_result() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
invalidateConditionalUpdate_result(TabletIngestClientService.invalidateConditionalUpdate_result) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
Performs a deep copy on other.
INVISIBLE_VISIBILITY - org.apache.accumulo.core.client.ConditionalWriter.Status
A condition contained a column visibility that could never be seen
isAccumuloStartEnabled() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
isActive() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.isActive
 
isActive() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.isActive
 
isActive(TInfo, long) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
isActive(TInfo, long) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
isActive(TInfo, long, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
isActive(TInfo, long, AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
isActive_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
isActive_args(ClientService.isActive_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
Performs a deep copy on other.
isActive_args(TInfo, long) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
isActive_call(TInfo, long, AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.isActive_call
 
isActive_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
isActive_result(boolean) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
isActive_result(ClientService.isActive_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
Performs a deep copy on other.
isAutoClean() - Method in class org.apache.accumulo.core.manager.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.
isCancelled() - Method in class org.apache.accumulo.core.util.CancelFlagFuture
 
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 interface org.apache.accumulo.core.client.MultiTableBatchWriter
Returns true if this batch writer has been closed.
isClosed() - Method in class org.apache.accumulo.core.clientImpl.MultiTableBatchWriterImpl
 
isCurrent() - Method in interface org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator.DataSource
 
isCurrent(ZooCache) - Method in class org.apache.accumulo.core.util.tables.TableMap
 
isDefault(PluginConfig) - Static method in class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
isDefaultLocalityGroup - Variable in class org.apache.accumulo.core.iteratorsImpl.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).
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.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
 
isDirectory() - Method in interface org.apache.accumulo.core.gc.Reference
Only return true if the reference is a directory.
isDirectory() - Method in class org.apache.accumulo.core.gc.ReferenceDirectory
 
isDirectory() - Method in class org.apache.accumulo.core.gc.ReferenceFile
 
isDone() - Method in class org.apache.accumulo.core.util.CancelFlagFuture
 
isDoTimestamps() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
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.iteratorsImpl.conf.ColumnSet
 
isEmpty() - Method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnToClassMapping
 
isEmpty() - Method in class org.apache.accumulo.core.security.Authorizations
Checks if this collection of authorizations is empty.
isEmpty(Properties) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
isEnabled() - Method in interface org.apache.accumulo.core.singletons.SingletonService
 
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.
isExternalId() - Method in class org.apache.accumulo.core.util.compaction.CompactionExecutorIdImpl
 
isFinished() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
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.clientImpl.CloneConfigurationImpl
 
isForce() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
isFormatedTid(String) - Static method in class org.apache.accumulo.core.fate.FateTxId
 
isFullMajorCompaction() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Return true if the compaction is a full major compaction.
isHasTimestamp() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
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.dataImpl.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.dataImpl.thrift.TRange
 
isIOException(Throwable) - Static method in class org.apache.accumulo.core.util.ShutdownUtil
 
isIpBasedRegex() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
isIsolated() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
isKeepMappings() - Method in interface org.apache.accumulo.core.client.admin.ImportConfiguration
isKeepMappings() - Method in class org.apache.accumulo.core.clientImpl.ImportConfigurationImpl
 
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 interface org.apache.accumulo.core.client.admin.ImportConfiguration
 
isKeepOffline() - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
isKeepOffline() - Method in class org.apache.accumulo.core.clientImpl.ImportConfigurationImpl
 
isKeyStoreSet() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
isLastInclusive() - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroupSeekCache
 
isLocalityGroupProperty(String) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
 
isLocked() - Method in class org.apache.accumulo.core.lock.ServiceLock
 
isLockHeld(String, String) - Method in interface org.apache.accumulo.core.clientImpl.TabletLocatorImpl.TabletServerLockChecker
 
isLockHeld(String, String) - Method in class org.apache.accumulo.core.clientImpl.ZookeeperLockChecker
 
isLockHeld(ZooCache, ZooUtil.LockID) - Static method in class org.apache.accumulo.core.lock.ServiceLock
 
isMeta() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
isMore() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
isMore() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
isolated - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
ISOLATED - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.clientImpl
 
IsolationException() - Constructor for exception org.apache.accumulo.core.clientImpl.IsolationException
 
IsolationException(Exception) - Constructor for exception org.apache.accumulo.core.clientImpl.IsolationException
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticate
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticateUser
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkClass
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkTableClass
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.createLocalUser
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getInstanceId
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getSystemProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedNamespaceProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedSystemProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedTableProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.isActive
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.ping
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticate
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticateUser
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeAuthorizations
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeLocalUserPassword
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkClass
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkNamespaceClass
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkTableClass
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.createLocalUser
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.dropLocalUser
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getDiskUsage
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getInstanceId
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getRootTabletLocation
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getSystemProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableConfiguration
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getUserAuthorizations
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedNamespaceProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedSystemProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedTableProperties
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getZooKeepers
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.isActive
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.listLocalUsers
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.ping
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeNamespacePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeSystemPermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeTablePermission
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.fails
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.success
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.throwsError
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.fails
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.success
 
isOneway() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.throwsError
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.cancel
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionCompleted
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionFailed
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompactionJob
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getRunningCompactions
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.updateCompactionStatus
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.cancel
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionCompleted
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionFailed
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompactionJob
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompletedCompactions
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getRunningCompactions
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.updateCompactionStatus
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.cancel
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getActiveCompactions
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompaction
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompactionId
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.cancel
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getActiveCompactions
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompaction
 
isOneway() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompactionId
 
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.manager.thrift.FateService.AsyncProcessor.beginFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.cancelFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.executeFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.finishFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.waitForFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.beginFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.cancelFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.executeFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.finishFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.waitForFateOperation
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getActiveTservers
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getDelegationToken
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getManagerStats
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.initiateFlush
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyNamespaceProperties
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifySystemProperties
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyTableProperties
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeNamespaceProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeSystemProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeTableProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportSplitExtent
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportTabletStatus
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setManagerGoalState
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setNamespaceProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setSystemProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setTableProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdown
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdownTabletServer
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForBalance
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForFlush
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getActiveTservers
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getDelegationToken
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getManagerStats
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.initiateFlush
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyNamespaceProperties
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifySystemProperties
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyTableProperties
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeNamespaceProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeSystemProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeTableProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportSplitExtent
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportTabletStatus
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setManagerGoalState
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setNamespaceProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setSystemProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setTableProperty
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdown
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdownTabletServer
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForBalance
 
isOneway() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForFlush
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.chop
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.flushTablet
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.loadTablet
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.splitTablet
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.unloadTablet
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.chop
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.flushTablet
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.loadTablet
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.splitTablet
 
isOneway() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.unloadTablet
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.applyUpdates
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.closeConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.closeUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.conditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.invalidateConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.loadFiles
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.update
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.applyUpdates
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.closeConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.closeUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.conditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.invalidateConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.loadFiles
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startConditionalUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startUpdate
 
isOneway() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.update
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.closeMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.closeScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.continueMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.continueScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.getActiveScans
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.closeMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.closeScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.continueMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.continueScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.getActiveScans
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startMultiScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startScan
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compact
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compactionJobFailed
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compactionJobFinished
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.contiuneGetSummaries
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.fastHalt
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.flush
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveCompactions
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveLogs
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getCompactionQueueInfo
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getHistoricalStats
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletServerStatus
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletStats
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.halt
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.removeLogs
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.reserveCompactionJob
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummaries
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesForPartition
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesFromFiles
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compact
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compactionJobFailed
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compactionJobFinished
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.contiuneGetSummaries
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.fastHalt
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.flush
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveCompactions
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveLogs
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getCompactionQueueInfo
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getHistoricalStats
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletServerStatus
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletStats
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.halt
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.removeLogs
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.reserveCompactionJob
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummaries
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesForPartition
 
isOneway() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesFromFiles
 
isOnline(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Check if a table is online through its current goal state only.
isOnline(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
isOpen() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
isPartNextKeyInclusive() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
isPreviousExtent(KeyExtent) - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
isPropagateDeletes() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
isPropertySet(Property) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
isPropertySet(Property) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
 
isPropertySet(Property) - Method in class org.apache.accumulo.core.conf.DefaultConfiguration
 
isPropertySet(Property) - Method in class org.apache.accumulo.core.conf.SiteConfiguration
 
isRangeInclusive() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
isReady(long, T) - Method in interface org.apache.accumulo.core.fate.ReadOnlyRepo
 
isReplaced() - Method in enum org.apache.accumulo.core.conf.Property
Checks if this property is replaced.
isRequired() - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
isRootTablet() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
isRunning() - Method in class org.apache.accumulo.core.util.OpTimer
Returns timer running state
isRunningLowOnMemory() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
Return whether or not the server is running low on memory
isRunningLowOnMemory() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Returns true when running in a server process and the GarbageCollectionLogger determines that the server is running low on memory.
isRunningLowOnMemory() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
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.clientImpl.ThriftTransportKey
 
isScanServer - Variable in class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
 
isSeekToBeginning() - Method in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
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(String) - Method in interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Properties with a default value will always return something when calling PluginEnvironment.Configuration.get(String), even if a user never set the property.
isSet(String) - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
isSet(ClientService.authenticate_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.authenticateUser_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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_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.clientImpl.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.clientImpl.thrift.ClientService.getRootTabletLocation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getSystemProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getSystemProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_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.clientImpl.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.clientImpl.thrift.ClientService.getTableConfiguration_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getTableProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getTableProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_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.clientImpl.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.clientImpl.thrift.ClientService.getUserAuthorizations_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getVersionedNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getVersionedNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getVersionedSystemProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getVersionedSystemProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getVersionedTableProperties_args._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClientService.getVersionedTableProperties_result._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.TDiskUsage
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftConcurrentModificationException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftNotActiveServiceException._Fields) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ThriftTest.throwsError_result
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.clientImpl.thrift.TInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TVersionedProperties._Fields) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.cancel_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.cancel_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.compactionCompleted_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.compactionCompleted_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.compactionFailed_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.compactionFailed_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.getCompactionJob_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.getCompactionJob_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.getCompletedCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.getCompletedCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.getRunningCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.getRunningCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.updateCompactionStatus_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactionCoordinatorService.updateCompactionStatus_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactorService.cancel_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactorService.cancel_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactorService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactorService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactorService.getRunningCompaction_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactorService.getRunningCompaction_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactorService.getRunningCompactionId_args._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompactorService.getRunningCompactionId_result._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCompactionStatusUpdate._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TExternalCompaction._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TExternalCompactionList._Fields) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UnknownCompactionIdException._Fields) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
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.dataImpl.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.dataImpl.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.dataImpl.thrift.IterInfo
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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.thrift.TRange
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TRowRange._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TSummaries._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TSummarizerConfiguration._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TSummary._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TSummaryRequest._Fields) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
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.dataImpl.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.manager.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.manager.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.manager.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.manager.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.manager.thrift.FateService.beginFateOperation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.cancelFateOperation_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FateService.cancelFateOperation_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_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.manager.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.manager.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.manager.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.manager.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.manager.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.manager.thrift.FateService.waitForFateOperation_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.getActiveTservers_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.getActiveTservers_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.getDelegationToken_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.getDelegationToken_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.getManagerStats_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.getManagerStats_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.initiateFlush_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.initiateFlush_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.modifyNamespaceProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.modifyNamespaceProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.modifySystemProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.modifySystemProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.modifyTableProperties_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.modifyTableProperties_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.removeNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.removeNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.removeSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.removeSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.removeTableProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.removeTableProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.reportSplitExtent_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.reportTabletStatus_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.setManagerGoalState_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.setManagerGoalState_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.setNamespaceProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.setNamespaceProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.setSystemProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.setSystemProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.setTableProperty_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.setTableProperty_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.shutdown_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.shutdown_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.shutdownTabletServer_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.shutdownTabletServer_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.waitForBalance_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.waitForBalance_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.waitForFlush_args._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerClientService.waitForFlush_result._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ManagerMonitorInfo._Fields) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
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.manager.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.manager.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.manager.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.manager.thrift.TabletSplit
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ThriftPropertyException._Fields) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
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.securityImpl.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.securityImpl.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.securityImpl.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.securityImpl.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.securityImpl.thrift.TDelegationTokenConfig
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletManagementClientService.chop_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletManagementClientService.flushTablet_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletManagementClientService.loadTablet_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletManagementClientService.splitTablet_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletManagementClientService.splitTablet_result._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletManagementClientService.unloadTablet_args._Fields) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
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.tabletingest.thrift.ConstraintViolationException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DataFileInfo._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.applyUpdates_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.closeConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.closeUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.closeUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.conditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.conditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.invalidateConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.invalidateConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.loadFiles_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.startConditionalUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.startConditionalUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.startUpdate_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.startUpdate_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.update_args._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletIngestClientService.update_result._Fields) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
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.tabletscan.thrift.ActiveScan
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ScanServerBusyException._Fields) - Method in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.closeMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.closeMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.closeScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.continueMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.continueMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.continueScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.continueScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.getActiveScans_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.getActiveScans_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.startMultiScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.startMultiScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.startScan_args._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletScanClientService.startScan_result._Fields) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
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.tabletscan.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.tabletscan.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.tabletscan.thrift.TSamplerConfiguration
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(InputFile._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
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(TabletServerClientService.compact_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.compactionJobFailed_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.compactionJobFinished_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.contiuneGetSummaries_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.contiuneGetSummaries_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.fastHalt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.flush_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getActiveCompactions_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getActiveCompactions_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getActiveLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getActiveLogs_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getCompactionQueueInfo_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getCompactionQueueInfo_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getHistoricalStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getHistoricalStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getTabletServerStatus_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getTabletServerStatus_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getTabletStats_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.getTabletStats_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.halt_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.halt_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.removeLogs_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.reserveCompactionJob_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.reserveCompactionJob_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.startGetSummaries_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.startGetSummaries_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.startGetSummariesForPartition_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.startGetSummariesForPartition_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.startGetSummariesFromFiles_args._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TabletServerClientService.startGetSummariesFromFiles_result._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_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(TCompactionQueueSummary._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TCompactionStats._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TExternalCompactionJob._Fields) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
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
isSetAfterPart(Key, PartialKey) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Indicates whether or not any part of key excluding part is set.
isSetAge() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
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.ActiveCompaction
Returns true if field age is set (has been assigned a value) and false otherwise
isSetArguments() - Method in class org.apache.accumulo.core.manager.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.dataImpl.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.clientImpl.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.tabletingest.thrift.TabletIngestClientService.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.tabletscan.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.manager.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.manager.thrift.ManagerMonitorInfo
Returns true if field badTServers is set (has been assigned a value) and false otherwise
isSetBatch() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.startScan_args
Returns true if field batchTimeOut is set (has been assigned a value) and false otherwise
isSetBounds() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
Returns true if field bounds is set (has been assigned a value) and false otherwise
isSetBulkImports() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
Returns true if field bulkImports is set (has been assigned a value) and false otherwise
isSetBulkImports() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
Returns true if field bulkImports is set (has been assigned a value) and false otherwise
isSetBulks() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
Returns true if field bulks is set (has been assigned a value) and false otherwise
isSetBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
Returns true if field busyTimeout is set (has been assigned a value) and false otherwise
isSetBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
Returns true if field busyTimeout is set (has been assigned a value) and false otherwise
isSetBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
Returns true if field busyTimeout is set (has been assigned a value) and false otherwise
isSetBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
Returns true if field busyTimeout 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.dataImpl.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.manager.thrift.ManagerClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletscan.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.dataImpl.thrift.TSummarizerConfiguration
Returns true if field classname is set (has been assigned a value) and false otherwise
isSetClassName() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.dataImpl.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.tabletscan.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.tabletscan.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.dataImpl.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.clientImpl.thrift.ThriftSecurityException
Returns true if field code is set (has been assigned a value) and false otherwise
isSetColFamily() - Method in class org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.tabletscan.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.dataImpl.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.dataImpl.thrift.TKey
Returns true if field colVisibility is set (has been assigned a value) and false otherwise
isSetCompactions() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
Returns true if field compactions is set (has been assigned a value) and false otherwise
isSetCompactor() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
Returns true if field compactor is set (has been assigned a value) and false otherwise
isSetCompactor() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
Returns true if field compactor is set (has been assigned a value) and false otherwise
isSetCompactor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
Returns true if field compactor is set (has been assigned a value) and false otherwise
isSetConditions() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
Returns true if field conditions is set (has been assigned a value) and false otherwise
isSetConfig() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
Returns true if field config is set (has been assigned a value) and false otherwise
isSetConfigId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
Returns true if field configId is set (has been assigned a value) and false otherwise
isSetConstrainClass() - Method in class org.apache.accumulo.core.dataImpl.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.dataImpl.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.securityImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getTableProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.compaction.thrift.CompactionCoordinatorService.cancel_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.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.compaction.thrift.CompactorService.getRunningCompaction_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_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.manager.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.manager.thrift.FateService.cancelFateOperation_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.manager.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.manager.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.manager.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.getManagerStats_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.setManagerGoalState_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tabletingest.thrift.TabletIngestClientService.loadFiles_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.update_args
Returns true if field credentials is set (has been assigned a value) and false otherwise
isSetCredentials() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.TabletServerClientService.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.TabletServerClientService.compactionJobFailed_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.TabletServerClientService.compactionJobFinished_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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.getCompactionQueueInfo_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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.reserveCompactionJob_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.TabletServerClientService.startGetSummaries_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.TabletServerClientService.startGetSummariesForPartition_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.TabletServerClientService.startGetSummariesFromFiles_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.dataImpl.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.tabletingest.thrift.TabletIngestClientService.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.dataImpl.thrift.TMutation
Returns true if field data is set (has been assigned a value) and false otherwise
isSetDataCacheHits() - Method in class org.apache.accumulo.core.manager.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.manager.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.manager.thrift.ManagerMonitorInfo
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
isSetDeletedFiles() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
Returns true if field deletedFiles is set (has been assigned a value) and false otherwise
isSetDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
Returns true if field description is set (has been assigned a value) and false otherwise
isSetDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
Returns true if field description is set (has been assigned a value) and false otherwise
isSetDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
Returns true if field description is set (has been assigned a value) and false otherwise
isSetDescription() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
Returns true if field description is set (has been assigned a value) and false otherwise
isSetDir() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
Returns true if field dir is set (has been assigned a value) and false otherwise
isSetDurability() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.update_args
Returns true if field durability 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.dataImpl.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.dataImpl.thrift.TRowRange
Returns true if field endRow is set (has been assigned a value) and false otherwise
isSetEndRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.TabletServerClientService.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.TabletServerClientService.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.dataImpl.thrift.TMutation
Returns true if field entries is set (has been assigned a value) and false otherwise
isSetEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
Returns true if field entries is set (has been assigned a value) and false otherwise
isSetEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
Returns true if field entries is set (has been assigned a value) and false otherwise
isSetEntriesRead() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
Returns true if field entriesRead 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
isSetEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
Returns true if field entriesRead is set (has been assigned a value) and false otherwise
isSetEntriesToBeCompacted() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
Returns true if field entriesToBeCompacted is set (has been assigned a value) and false otherwise
isSetEntriesWritten() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
Returns true if field entriesWritten 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
isSetEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
Returns true if field entriesWritten 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.tabletingest.thrift.DataFileInfo
Returns true if field estimatedSize is set (has been assigned a value) and false otherwise
isSetEx() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
Returns true if field ex is set (has been assigned a value) and false otherwise
isSetExecutionHints() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
Returns true if field executionHints is set (has been assigned a value) and false otherwise
isSetExecutionHints() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
Returns true if field executionHints is set (has been assigned a value) and false otherwise
isSetExpirationDate() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
isSetExpirationDate() - Method in class org.apache.accumulo.core.securityImpl.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.securityImpl.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.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tabletscan.thrift.ActiveScan
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExtent() - Method in exception org.apache.accumulo.core.tabletscan.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.tabletscan.thrift.TSampleNotPresentException
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.ActiveCompaction
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.TabletServerClientService.compactionJobFailed_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.TabletServerClientService.compactionJobFinished_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 class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Returns true if field extent is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
Returns true if field externalCompactionId is set (has been assigned a value) and false otherwise
isSetExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Returns true if field externalCompactionId 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.dataImpl.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.dataImpl.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.manager.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.TabletServerClientService.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.tabletingest.thrift.TabletIngestClientService.loadFiles_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.TabletServerClientService.startGetSummariesFromFiles_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.TExternalCompactionJob
Returns true if field files is set (has been assigned a value) and false otherwise
isSetFilesContaining() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
Returns true if field filesContaining is set (has been assigned a value) and false otherwise
isSetFilesExceeding() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
Returns true if field filesExceeding is set (has been assigned a value) and false otherwise
isSetFileSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
Returns true if field fileSize is set (has been assigned a value) and false otherwise
isSetFileSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
Returns true if field fileSize is set (has been assigned a value) and false otherwise
isSetFilesLarge() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
Returns true if field filesLarge is set (has been assigned a value) and false otherwise
isSetFinished() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
Returns true if field finished 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.manager.thrift.ManagerClientService.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.manager.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.manager.thrift.ManagerClientService.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.dataImpl.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.tablet.thrift.TabletManagementClientService.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.manager.thrift.ManagerMonitorInfo
Returns true if field goalState is set (has been assigned a value) and false otherwise
isSetHasTimestamp() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
Returns true if field hasTimestamp is set (has been assigned a value) and false otherwise
isSetHeaders() - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
Returns true if field headers is set (has been assigned a value) and false otherwise
isSetHoldTime() - Method in class org.apache.accumulo.core.manager.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.dataImpl.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.securityImpl.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.tabletscan.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.manager.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.manager.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.dataImpl.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.dataImpl.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.manager.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.manager.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.securityImpl.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.securityImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.tabletscan.thrift.TabletScanClientService.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.clientImpl.AuthenticationTokenIdentifier
 
isSetIssueDate() - Method in class org.apache.accumulo.core.securityImpl.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.dataImpl.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
isSetIteratorSettings() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Returns true if field iteratorSettings is set (has been assigned a value) and false otherwise
isSetIterName() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
Returns true if field iterName is set (has been assigned a value) and false otherwise
isSetJob() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
Returns true if field job is set (has been assigned a value) and false otherwise
isSetKey() - Method in class org.apache.accumulo.core.dataImpl.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.securityImpl.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.securityImpl.thrift.TAuthenticationTokenIdentifier
Returns true if field keyId is set (has been assigned a value) and false otherwise
isSetKind() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Returns true if field kind 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.manager.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.manager.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.securityImpl.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.unloadTablet_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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.halt_args
Returns true if field lock is set (has been assigned a value) and false otherwise
isSetLogSorts() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
Returns true if field logSorts is set (has been assigned a value) and false otherwise
isSetLookups() - Method in class org.apache.accumulo.core.manager.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.manager.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.manager.thrift.ManagerClientService.waitForFlush_args
Returns true if field maxLoops is set (has been assigned a value) and false otherwise
isSetMessage() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMetadataFileEntry() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
Returns true if field metadataFileEntry is set (has been assigned a value) and false otherwise
isSetMinors() - Method in class org.apache.accumulo.core.manager.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
isSetModulus() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
Returns true if field modulus is set (has been assigned a value) and false otherwise
isSetMore() - Method in class org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.manager.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.manager.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.clientImpl.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.manager.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceProperties_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
Returns true if field ns is set (has been assigned a value) and false otherwise
isSetNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.continueScan_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.TabletServerClientService.contiuneGetSummaries_result
Returns true if field nssi is set (has been assigned a value) and false otherwise
isSetNste() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.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.tabletingest.thrift.TabletIngestClientService.update_result
Returns true if field nste is set (has been assigned a value) and false otherwise
isSetNste() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.startScan_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.dataImpl.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.manager.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.manager.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.clientImpl.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.manager.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.manager.thrift.FateService.cancelFateOperation_args
Returns true if field opid is set (has been assigned a value) and false otherwise
isSetOpid() - Method in class org.apache.accumulo.core.manager.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.manager.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.manager.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.dataImpl.thrift.TSummarizerConfiguration
Returns true if field options is set (has been assigned a value) and false otherwise
isSetOptions() - Method in class org.apache.accumulo.core.manager.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.tabletscan.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.manager.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
isSetOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Returns true if field outputFile is set (has been assigned a value) and false otherwise
isSetOverrides() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Returns true if field overrides is set (has been assigned a value) and false otherwise
isSetPartNextKey() - Method in class org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.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.clientImpl.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.clientImpl.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.securityImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.dataImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.securityImpl.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.securityImpl.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.dataImpl.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.TabletServerClientService.reserveCompactionJob_args
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.TCompactionQueueSummary
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.manager.thrift.RecoveryStatus
Returns true if field progress is set (has been assigned a value) and false otherwise
isSetPropagateDeletes() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Returns true if field propagateDeletes is set (has been assigned a value) and false otherwise
isSetProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
Returns true if field properties 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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.setTableProperty_args
Returns true if field property is set (has been assigned a value) and false otherwise
isSetProperty() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
Returns true if field property is set (has been assigned a value) and false otherwise
isSetQueryByteRate() - Method in class org.apache.accumulo.core.manager.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.manager.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
isSetQueue() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
Returns true if field queue is set (has been assigned a value) and false otherwise
isSetQueued() - Method in class org.apache.accumulo.core.manager.thrift.Compacting
Returns true if field queued is set (has been assigned a value) and false otherwise
isSetQueueName() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
Returns true if field queueName is set (has been assigned a value) and false otherwise
isSetQueueName() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
Returns true if field queueName is set (has been assigned a value) and false otherwise
isSetQueueName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
Returns true if field queueName 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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.startScan_args
Returns true if field readaheadThreshold 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.manager.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.manager.thrift.TableInfo
Returns true if field recsInMemory is set (has been assigned a value) and false otherwise
isSetRemainder() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
Returns true if field remainder is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequestTime() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.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.manager.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.dataImpl.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.manager.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.manager.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.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.dataImpl.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.dataImpl.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.manager.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.manager.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getConfiguration_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.compaction.thrift.CompactorService.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.compaction.thrift.CompactorService.getRunningCompaction_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_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.manager.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.manager.thrift.FateService.cancelFateOperation_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.manager.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.manager.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.manager.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.getManagerStats_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.setManagerGoalState_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.tablet.thrift.TabletManagementClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.update_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSec() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.TabletServerClientService.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.TabletServerClientService.getCompactionQueueInfo_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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.reserveCompactionJob_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.TabletServerClientService.startGetSummaries_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.TabletServerClientService.startGetSummariesForPartition_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.TabletServerClientService.startGetSummariesFromFiles_result
Returns true if field sec is set (has been assigned a value) and false otherwise
isSetSecret() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
Returns true if field secret is set (has been assigned a value) and false otherwise
isSetServ() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
Returns true if field serv is set (has been assigned a value) and false otherwise
isSetServer() - Method in class org.apache.accumulo.core.manager.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerMonitorInfo
Returns true if field serversShuttingDown is set (has been assigned a value) and false otherwise
isSetSessID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.dataImpl.thrift.TConditionalSession
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSessionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
Returns true if field sessionId is set (has been assigned a value) and false otherwise
isSetSetTime() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
Returns true if field setTime is set (has been assigned a value) and false otherwise
isSetSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
Returns true if field size is set (has been assigned a value) and false otherwise
isSetSources() - Method in class org.apache.accumulo.core.dataImpl.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.manager.thrift.ManagerClientService.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.tablet.thrift.TabletManagementClientService.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
isSetSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
Returns true if field ssbe is set (has been assigned a value) and false otherwise
isSetSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
Returns true if field ssbe is set (has been assigned a value) and false otherwise
isSetSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
Returns true if field ssbe is set (has been assigned a value) and false otherwise
isSetSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
Returns true if field ssbe is set (has been assigned a value) and false otherwise
isSetSsiList() - Method in class org.apache.accumulo.core.tabletscan.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.startScan_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.ActiveCompaction
Returns true if field ssiList is set (has been assigned a value) and false otherwise
isSetSsio() - Method in class org.apache.accumulo.core.tabletscan.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.startScan_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.ActiveCompaction
Returns true if field ssio is set (has been assigned a value) and false otherwise
isSetStart() - Method in class org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.thrift.TRowRange
Returns true if field startRow is set (has been assigned a value) and false otherwise
isSetStartRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.TabletServerClientService.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.TabletServerClientService.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.manager.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.compaction.thrift.TCompactionStatusUpdate
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.accumulo.core.manager.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.manager.thrift.ManagerClientService.setManagerGoalState_args
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
Returns true if field state is set (has been assigned a value) and false otherwise
isSetState() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
Returns true if field state is set (has been assigned a value) and false otherwise
isSetStats() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
Returns true if field stats is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class org.apache.accumulo.core.dataImpl.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.manager.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.manager.thrift.ManagerClientService.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.dataImpl.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.dataImpl.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.manager.thrift.ManagerClientService.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceProperties_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getSystemProperties_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getTableProperties_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.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.compaction.thrift.CompactorService.getRunningCompaction_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_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.manager.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.manager.thrift.FateService.cancelFateOperation_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.manager.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.getManagerStats_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.startUpdate_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.TabletServerClientService.contiuneGetSummaries_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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.getCompactionQueueInfo_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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.reserveCompactionJob_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.TabletServerClientService.startGetSummaries_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.TabletServerClientService.startGetSummariesForPartition_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.TabletServerClientService.startGetSummariesFromFiles_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
isSetSummaries() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
Returns true if field summaries is set (has been assigned a value) and false otherwise
isSetSummarizerPattern() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
Returns true if field summarizerPattern is set (has been assigned a value) and false otherwise
isSetSummarizers() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
Returns true if field summarizers is set (has been assigned a value) and false otherwise
isSetSummary() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
Returns true if field summary is set (has been assigned a value) and false otherwise
isSetSymbols() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.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.manager.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.clientImpl.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.dataImpl.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.clientImpl.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.clientImpl.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.dataImpl.thrift.TSummaryRequest
Returns true if field tableId is set (has been assigned a value) and false otherwise
isSetTableId() - Method in class org.apache.accumulo.core.tabletscan.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.tabletingest.thrift.TabletIngestClientService.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.manager.thrift.ManagerMonitorInfo
Returns true if field tableMap is set (has been assigned a value) and false otherwise
isSetTableMap() - Method in class org.apache.accumulo.core.manager.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.clientImpl.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.clientImpl.thrift.ClientService.getTableProperties_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.modifyTableProperties_args
Returns true if field tableName is set (has been assigned a value) and false otherwise
isSetTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.clientImpl.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.clientImpl.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.manager.thrift.ManagerClientService.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.manager.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.manager.thrift.ManagerClientService.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.clientImpl.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.clientImpl.thrift.ClientService.hasTablePermission_args
Returns true if field tblPerm is set (has been assigned a value) and false otherwise
isSetTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
Returns true if field tcme is set (has been assigned a value) and false otherwise
isSetTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
Returns true if field tcme is set (has been assigned a value) and false otherwise
isSetTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
Returns true if field tcme is set (has been assigned a value) and false otherwise
isSetTid() - Method in class org.apache.accumulo.core.clientImpl.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.tabletingest.thrift.TabletIngestClientService.loadFiles_args
Returns true if field tid is set (has been assigned a value) and false otherwise
isSetTime() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
isSetTimesPaused() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
Returns true if field timesPaused is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getTableProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.compaction.thrift.CompactionCoordinatorService.cancel_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.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.compaction.thrift.CompactorService.getRunningCompaction_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_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.manager.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.manager.thrift.FateService.cancelFateOperation_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.manager.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.manager.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.manager.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.getManagerStats_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.setManagerGoalState_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tablet.thrift.TabletManagementClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.loadFiles_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.update_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.TabletServerClientService.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.TabletServerClientService.compactionJobFailed_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.TabletServerClientService.compactionJobFinished_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.TabletServerClientService.contiuneGetSummaries_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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.getCompactionQueueInfo_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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.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.TabletServerClientService.reserveCompactionJob_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.TabletServerClientService.startGetSummaries_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.TabletServerClientService.startGetSummariesForPartition_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.TabletServerClientService.startGetSummariesFromFiles_args
Returns true if field tinfo is set (has been assigned a value) and false otherwise
isSetTmfe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.startScan_result
Returns true if field tmfe is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
Returns true if field tnase is set (has been assigned a value) and false otherwise
isSetToAuth() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.securityImpl.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.securityImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.thrift.ClientService.getNamespaceProperties_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.getTableProperties_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.clientImpl.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.manager.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.manager.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.waitForFlush_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTope() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
Returns true if field tope is set (has been assigned a value) and false otherwise
isSetTotalFiles() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
Returns true if field totalFiles is set (has been assigned a value) and false otherwise
isSetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
Returns true if field tpe is set (has been assigned a value) and false otherwise
isSetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
Returns true if field tpe is set (has been assigned a value) and false otherwise
isSetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
Returns true if field tpe is set (has been assigned a value) and false otherwise
isSetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
Returns true if field tpe is set (has been assigned a value) and false otherwise
isSetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
Returns true if field tpe is set (has been assigned a value) and false otherwise
isSetTs() - Method in class org.apache.accumulo.core.dataImpl.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.manager.thrift.ManagerMonitorInfo
Returns true if field tServerInfo is set (has been assigned a value) and false otherwise
isSetTserverLock() - Method in class org.apache.accumulo.core.dataImpl.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.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.dataImpl.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.clientImpl.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.clientImpl.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.tabletscan.thrift.ActiveScan
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
isSetUnassignedTablets() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
Returns true if field unassignedTablets is set (has been assigned a value) and false otherwise
isSetUpdateID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.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.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
Returns true if field updateID is set (has been assigned a value) and false otherwise
isSetUpdates() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
Returns true if field updates is set (has been assigned a value) and false otherwise
isSetUsage() - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.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.tabletscan.thrift.ActiveScan
Returns true if field user is set (has been assigned a value) and false otherwise
isSetUserCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Returns true if field userCompactionId is set (has been assigned a value) and false otherwise
isSetVal() - Method in class org.apache.accumulo.core.dataImpl.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.dataImpl.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.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.manager.thrift.ManagerClientService.setTableProperty_args
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValue() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
Returns true if field value is set (has been assigned a value) and false otherwise
isSetValues() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
Returns true if field values is set (has been assigned a value) and false otherwise
isSetVersion() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
Returns true if field version is set (has been assigned a value) and false otherwise
isSetVersion() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
Returns true if field version is set (has been assigned a value) and false otherwise
isSetViolationCode() - Method in class org.apache.accumulo.core.dataImpl.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.dataImpl.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.dataImpl.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.tabletingest.thrift.ConstraintViolationException
Returns true if field violationSummaries is set (has been assigned a value) and false otherwise
isSetVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
Returns true if field vProperties is set (has been assigned a value) and false otherwise
isSetVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
Returns true if field vProperties is set (has been assigned a value) and false otherwise
isSetVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
Returns true if field vProperties is set (has been assigned a value) and false otherwise
isSetWaitForWrites() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.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.tabletscan.thrift.TabletScanClientService.startScan_args
Returns true if field waitForWrites is set (has been assigned a value) and false otherwise
isShutdownInProgress() - Static method in class org.apache.accumulo.core.util.ShutdownUtil
Determine if a JVM shutdown is in progress.
isSsl() - Method in class org.apache.accumulo.core.clientImpl.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.dataImpl.thrift.TRange
 
isStopKeyInclusive() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
isStopTabletServers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
isSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
isSuccess() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
ISSUE_DATE - org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
issueDate - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
IsSupportedCompressionAlgorithm() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty.IsSupportedCompressionAlgorithm
 
isTableOnline(TableId) - Method in interface org.apache.accumulo.core.spi.balancer.BalancerEnvironment
Accumulo plugins working with a table may need to know if the table is online or not before operating on it.
isTimeSet() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
isTrustStoreSet() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
isUseEvictionThread() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
isUserCompaction() - Method in interface org.apache.accumulo.core.iterators.IteratorEnvironment
True if compaction was user initiated.
isValidBooleanPropertyKey(String) - Static method in enum org.apache.accumulo.core.conf.Property
Checks if the given property key is a valid property and is of type boolean.
isValidContext(String) - Static method in class org.apache.accumulo.core.classloader.ClassLoaderUtil
 
isValidDirCol(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Matches regex for a tablet directory like "default_tablet" or "t-000009x"
isValidEncoding(String) - Static method in class org.apache.accumulo.core.iteratorsImpl.conf.ColumnSet
 
isValidFormat(String) - Method in enum org.apache.accumulo.core.conf.PropertyType
Checks if the given value is valid for this type.
isValidProperty(String, String) - Static method in enum org.apache.accumulo.core.conf.Property
Checks if the given property and value are valid.
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.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
isWaitForWrites() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
isWalRefLoggingEnabled() - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
iter - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
ITER_INFO_COMPARATOR - Static variable in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
 
ITER_NAME - org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
 
iterateUntil(Function<T, CompletableFuture<T>>, Predicate<T>, T) - Static method in class org.apache.accumulo.core.util.CompletableFutureUtil
Iterate some function until a given condition is met.
IterationInterruptedException - Exception in org.apache.accumulo.core.iteratorsImpl.system
Exception thrown if an interrupt flag is detected.
IterationInterruptedException() - Constructor for exception org.apache.accumulo.core.iteratorsImpl.system.IterationInterruptedException
 
IterationInterruptedException(String) - Constructor for exception org.apache.accumulo.core.iteratorsImpl.system.IterationInterruptedException
 
iterator() - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
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 interface org.apache.accumulo.core.client.PluginEnvironment.Configuration
Returns an iterator over all properties.
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.clientImpl.bulk.Bulk.Files
 
iterator() - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
iterator() - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
iterator() - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
iterator() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReader
 
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.iteratorsImpl.system.SourceSwitchingIterator.DataSource
 
iterator() - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata
 
iterator() - Method in class org.apache.accumulo.core.security.Authorizations
 
iterator() - Method in class org.apache.accumulo.core.util.ConfigurationImpl
 
iterator() - Method in class org.apache.accumulo.core.util.PreAllocatedArray
 
ITERATOR_CLASS - org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
ITERATOR_SETTINGS - org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
IteratorAdapter - Class in org.apache.accumulo.core.iterators
 
IteratorAdapter(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.IteratorAdapter
 
IteratorBuilder - Class in org.apache.accumulo.core.iteratorsImpl
Builder class for setting up the iterator stack.
IteratorBuilder.IteratorBuilderEnv - Interface in org.apache.accumulo.core.iteratorsImpl
 
IteratorBuilder.IteratorBuilderOptions - Interface in org.apache.accumulo.core.iteratorsImpl
 
IteratorBuilderImpl - Class in org.apache.accumulo.core.iteratorsImpl
 
IteratorBuilderImpl(Collection<IterInfo>) - Constructor for class org.apache.accumulo.core.iteratorsImpl.IteratorBuilderImpl
 
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.
IteratorConfiguration - Interface in org.apache.accumulo.core.spi.common
Provides information about a configured Accumulo Iterator
IteratorConfigUtil - Class in org.apache.accumulo.core.iteratorsImpl
Utility class for configuring iterators.
IteratorConfigUtil() - Constructor for class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
 
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.dataImpl.thrift.TCondition
 
iterators - Variable in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
ITERATORS - org.apache.accumulo.core.dataImpl.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.
iteratorSettings - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
IteratorUtil - Class in org.apache.accumulo.core.iterators
Utility class for 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.
IterConfig() - Constructor for class org.apache.accumulo.core.clientImpl.CompressedIterators.IterConfig
 
IterInfo - Class in org.apache.accumulo.core.dataImpl.thrift
 
IterInfo() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
IterInfo(int, String, String) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
IterInfo(IterInfo) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.IterInfo
Performs a deep copy on other.
IterInfo._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
iterName - Variable in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 

J

job - Variable in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
JOB - org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
 
JOB_COMPARATOR - Static variable in class org.apache.accumulo.core.util.compaction.CompactionJobPrioritizer
 

K

kDepth - Static variable in class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
 
keepers - Variable in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
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.
key - Variable in class org.apache.accumulo.core.dataImpl.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.dataImpl.thrift.TKeyValue._Fields
 
KEY_EXTENT - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args._Fields
 
KEY_EXTENT - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args._Fields
 
KEY_ID - org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
 
KEY_ID - org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
KEY_URI_PROPERTY - Static variable in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
KeyBuilder - Class in org.apache.accumulo.core.data
A builder used to build Keys by defining their components.
KeyBuilder() - Constructor for class org.apache.accumulo.core.data.KeyBuilder
 
KeyBuilder.Build - Interface in org.apache.accumulo.core.data
Base Builder interface which can be used to set the Key timestamp and delete marker and to build the Key.
KeyBuilder.ColumnFamilyStep - Interface in org.apache.accumulo.core.data
Builder step used to set the columnFamily part of the Key.
KeyBuilder.ColumnQualifierStep - Interface in org.apache.accumulo.core.data
Builder step used to set the column qualifier part of the Key.
KeyBuilder.ColumnVisibilityStep - Interface in org.apache.accumulo.core.data
Builder step used to set the column visibility part of the Key.
KeyBuilder.RowStep - Interface in org.apache.accumulo.core.data
Builder step used to set the row part of the Key.
keyExtent - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
keyExtent - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
KeyExtent - Class in org.apache.accumulo.core.dataImpl
keeps track of information needed to identify a tablet
KeyExtent(TableId, Text, Text) - Constructor for class org.apache.accumulo.core.dataImpl.KeyExtent
Create a new KeyExtent from its components.
KeyFunctor - Interface in org.apache.accumulo.core.file.keyfunctor
 
keyId - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
keyId - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
keyPos - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
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.
keystore(CharSequence) - Method in interface org.apache.accumulo.core.client.AccumuloClient.SslOptions
Build with SSL key store
keystore(CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
keystore(CharSequence, CharSequence, CharSequence) - Method in interface org.apache.accumulo.core.client.AccumuloClient.SslOptions
Build with SSL key store
keystore(CharSequence, CharSequence, CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
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.
keyword() - Method in class org.apache.accumulo.core.file.rfile.CreateEmpty
 
keyword() - Method in class org.apache.accumulo.core.file.rfile.GenerateSplits
 
keyword() - Method in class org.apache.accumulo.core.file.rfile.PrintInfo
 
keyword() - Method in class org.apache.accumulo.core.file.rfile.SplitLarge
 
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.Version
 
kind - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
kind - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
KIND - org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 

L

LARGE_FILE_COMPRESSION_THRESHOLD - Static variable in class org.apache.accumulo.core.client.admin.compaction.CompressionConfigurer
 
LARGE_FILE_COMPRESSION_TYPE - Static variable in class org.apache.accumulo.core.client.admin.compaction.CompressionConfigurer
 
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.user.LargeRowFilter
 
last - Variable in class org.apache.accumulo.core.gc.thrift.GCStatus
 
last - Variable in class org.apache.accumulo.core.metadata.TabletLocationState
 
last(String, String) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
last(TServerInstance) - Static method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
LAST - org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
LAST - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
LAST - org.apache.accumulo.core.metadata.schema.TabletMetadata.LocationType
 
LAST_CONTACT - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
LAST_LOCATION_MODE - org.apache.accumulo.core.conf.PropertyType
 
LAST_LOG - org.apache.accumulo.core.gc.thrift.GCStatus._Fields
 
LAST_STATUS - org.apache.accumulo.core.manager.thrift.DeadServer._Fields
 
lastContact - Variable in class org.apache.accumulo.core.manager.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.manager.thrift.DeadServer
 
lastTabletRow - Variable in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
lastUpdate - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
LazySingletons - Class in org.apache.accumulo.core.util
This class provides easy access to global, immutable, lazily-instantiated, and thread-safe singleton resources.
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.
length(long) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
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.securityImpl.thrift.TDelegationTokenConfig
 
LIFETIME - org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
 
LinkingIterator - Class in org.apache.accumulo.core.metadata.schema
Tablets for a table in the metadata table should form a linked list.
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.clientImpl.NamespaceOperationsImpl
 
list() - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
list() - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
list() - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
list all transaction ids in store.
list() - Method in class org.apache.accumulo.core.fate.ZooStore
 
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.clientImpl.NamespaceOperationsHelper
 
listConstraints(String) - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.NamespaceOperationsHelper
 
listIterators(String) - Method in class org.apache.accumulo.core.clientImpl.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.clientImpl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
listLocalUsers() - Constructor for class org.apache.accumulo.core.clientImpl.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.clientImpl.SecurityOperationsImpl
 
listLocalUsers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
listLocalUsers(TInfo, TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
listLocalUsers(TInfo, TCredentials, AsyncMethodCallback<Set<String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
listLocalUsers(TInfo, TCredentials, AsyncMethodCallback<Set<String>>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
listLocalUsers_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
listLocalUsers_args(ClientService.listLocalUsers_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
Performs a deep copy on other.
listLocalUsers_args(TInfo, TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
listLocalUsers_call(TInfo, TCredentials, AsyncMethodCallback<Set<String>>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.listLocalUsers_call
 
listLocalUsers_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
listLocalUsers_result(Set<String>, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
listLocalUsers_result(ClientService.listLocalUsers_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
Performs a deep copy on other.
listOnlineTabletsForTable(TabletServerId, TableId) - Method in interface org.apache.accumulo.core.spi.balancer.BalancerEnvironment
Fetch the tablets for the given table by asking the tablet server.
listSplits(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
listSplits(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
listSplits(String, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
listSplits(String, int) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
This version of listSplits is called when the maxSplits options is provided.
listSummarizers(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
listSummarizers(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
listTabletLocations(TableId) - Method in interface org.apache.accumulo.core.spi.balancer.BalancerEnvironment
Fetch the locations for each of tableId's tablets from the metadata table.
load() - Method in interface org.apache.accumulo.core.client.admin.TableOperations.ImportOptions
Loads the files into the table.
load() - Method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
load(int, Map<String, byte[]>) - Method in interface org.apache.accumulo.core.spi.cache.BlockCache.Loader
Loads a block.
load(Configuration, RFileSource, String, Predicate<SummarizerConfiguration>, SummarizerFactory, CryptoService) - Static method in class org.apache.accumulo.core.summary.SummaryReader
 
load(FileSystem, Configuration, SummarizerFactory, Path, Predicate<SummarizerConfiguration>, BlockCache, BlockCache, Cache<String, Long>, CryptoService) - Static method in class org.apache.accumulo.core.summary.SummaryReader
 
LOAD_FAILURE - org.apache.accumulo.core.manager.thrift.TabletLoadState
 
loadClass(String, Class<U>) - Static method in class org.apache.accumulo.core.classloader.ClassLoaderUtil
 
loadClass(String, String, Class<U>) - Static method in class org.apache.accumulo.core.classloader.ClassLoaderUtil
 
loaded(KeyExtent, TServerInstance) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
LOADED - org.apache.accumulo.core.manager.thrift.TabletLoadState
 
LOADED - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
loadFiles() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.loadFiles
 
loadFiles() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.loadFiles
 
loadFiles(TInfo, TCredentials, long, String, Map<TKeyExtent, Map<String, DataFileInfo>>, boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
loadFiles(TInfo, TCredentials, long, String, Map<TKeyExtent, Map<String, DataFileInfo>>, boolean) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Iface
 
loadFiles(TInfo, TCredentials, long, String, Map<TKeyExtent, Map<String, DataFileInfo>>, boolean, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient
 
loadFiles(TInfo, TCredentials, long, String, Map<TKeyExtent, Map<String, DataFileInfo>>, boolean, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncIface
 
loadFiles_args() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
loadFiles_args(TInfo, TCredentials, long, String, Map<TKeyExtent, Map<String, DataFileInfo>>, boolean) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
loadFiles_args(TabletIngestClientService.loadFiles_args) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
Performs a deep copy on other.
loadFiles_call(TInfo, TCredentials, long, String, Map<TKeyExtent, Map<String, DataFileInfo>>, boolean, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.loadFiles_call
 
loadFileTo(String, LoadPlan.RangeType, byte[], byte[]) - Method in interface org.apache.accumulo.core.data.LoadPlan.Builder
Specify the row range where a file should be loaded.
loadFileTo(String, LoadPlan.RangeType, CharSequence, CharSequence) - Method in interface org.apache.accumulo.core.data.LoadPlan.Builder
Specify the row range where a file should be loaded.
loadFileTo(String, LoadPlan.RangeType, Text, Text) - Method in interface org.apache.accumulo.core.data.LoadPlan.Builder
Specify the row range where a file should be loaded.
loading(KeyExtent, TServerInstance) - Static method in class org.apache.accumulo.core.logging.TabletLogger
A tablet server has received an assignment message from manager and queued the tablet for loading.
LOADING - org.apache.accumulo.core.manager.thrift.BulkImportState
 
loadIterators(SortedKeyValueIterator<Key, Value>, IteratorBuilder) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
Load a stack of iterators provided in the iterator builder, starting with source.
loadIterConf(IteratorUtil.IteratorScope, List<IterInfo>, Map<String, Map<String, String>>, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
 
loadKekFromUri(String) - Static method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
LoadMappingIterator - Class in org.apache.accumulo.core.clientImpl.bulk
Iterator for reading the Bulk Load Mapping JSON.
LoadPlan - Class in org.apache.accumulo.core.data
Information about where to load files into an Accumulo table.
LoadPlan.Builder - Interface in org.apache.accumulo.core.data
 
LoadPlan.Destination - Class in org.apache.accumulo.core.data
Mapping of a file to a row range with an associated range type.
LoadPlan.RangeType - Enum in org.apache.accumulo.core.data
 
loadTablet() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.loadTablet
 
loadTablet() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.loadTablet
 
loadTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
loadTablet(TInfo, TCredentials, String, TKeyExtent) - Method in interface org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Iface
 
loadTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient
 
loadTablet(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncIface
 
loadTablet_args() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
loadTablet_args(TInfo, TCredentials, String, TKeyExtent) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
loadTablet_args(TabletManagementClientService.loadTablet_args) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
Performs a deep copy on other.
loadTablet_call(TInfo, TCredentials, String, TKeyExtent, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.loadTablet_call
 
LOCALITY_GROUP - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
localityGroup - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
LocalityGroup(Map<ByteSequence, MutableLong>, boolean) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroup
 
LocalityGroup(InterruptibleIterator, Map<ByteSequence, MutableLong>, boolean) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroup
 
LocalityGroupContext(LocalityGroupIterator.LocalityGroup[]) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator.LocalityGroupContext
 
LocalityGroupIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
 
LocalityGroupIterator(LocalityGroupIterator.LocalityGroup[]) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator
 
LocalityGroupIterator.LocalityGroup - Class in org.apache.accumulo.core.iteratorsImpl.system
 
LocalityGroupIterator.LocalityGroupContext - Class in org.apache.accumulo.core.iteratorsImpl.system
 
LocalityGroupIterator.LocalityGroupSeekCache - Class in org.apache.accumulo.core.iteratorsImpl.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.iteratorsImpl.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.clientImpl.TableOperationsImpl
 
locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.clientImpl.RootTabletLocator
 
locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.clientImpl.TabletLocator
 
locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
locateTablet(ClientContext, Text, boolean, boolean) - Method in class org.apache.accumulo.core.clientImpl.TimeoutTabletLocator
 
LOCATION - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
locationObtainer - Variable in class org.apache.accumulo.core.clientImpl.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.tablet.thrift.TabletManagementClientService.chop_args
 
lock - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
lock - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
lock - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
lock - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
lock(ServiceLock.AccumuloLockWatcher, ServiceLockData) - Method in class org.apache.accumulo.core.lock.ServiceLock
 
LOCK - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args._Fields
 
LOCK - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args._Fields
 
LOCK - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args._Fields
 
LOCK - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args._Fields
 
LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args._Fields
 
LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args._Fields
 
LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args._Fields
 
LOCK - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args._Fields
 
LOCK_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
LOCK_DELETED - org.apache.accumulo.core.lock.ServiceLock.LockLossReason
 
LOCK_QUAL - 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
LockID(String, String) - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooUtil.LockID
 
LockID(String, String, long) - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooUtil.LockID
 
LOG - org.apache.accumulo.core.client.Durability
Write mutations the the write-ahead log.
LOG - org.apache.accumulo.core.tabletingest.thrift.TDurability
 
LOG - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
LOG - Static variable in class org.apache.accumulo.core.trace.TraceUtil
 
LOG_SORTS - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
LogColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LogColumnFamily
 
logCompletion(Logger, String) - Method in class org.apache.accumulo.core.util.Retry
 
LogEntry - Class in org.apache.accumulo.core.tabletserver.log
 
LogEntry(KeyExtent, long, String) - Constructor for class org.apache.accumulo.core.tabletserver.log.LogEntry
 
LOGGER - org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment.Scope
 
Logging - Class in org.apache.accumulo.core.logging
 
Logging() - Constructor for class org.apache.accumulo.core.logging.Logging
 
LOGICAL - org.apache.accumulo.core.client.admin.TimeType
Used to guarantee ordering of data sequentially as inserted
logInterval(long, TimeUnit) - Method in interface org.apache.accumulo.core.util.Retry.NeedsLogInterval
 
logRetry(Logger, String) - Method in class org.apache.accumulo.core.util.Retry
 
logRetry(Logger, String, Throwable) - Method in class org.apache.accumulo.core.util.Retry
 
LOGS - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
logSorts - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
logStats() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
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
 
lookup(Key) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
lookup(Text) - Method in interface org.apache.accumulo.core.clientImpl.bulk.BulkImport.KeyExtentCache
 
lookupInstanceName(ZooCache, InstanceId) - Static method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
Given a zooCache and instanceId, look up the instance name.
lookupNamespaceId(ClientContext, String) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Look for namespace ID in ZK.
lookups - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
LOOKUPS - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
lookupTablet(ClientContext, TabletLocator.TabletLocation, Text, Text, TabletLocator) - Method in interface org.apache.accumulo.core.clientImpl.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.clientImpl.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
 
lostLock(ServiceLock.LockLossReason) - Method in interface org.apache.accumulo.core.lock.ServiceLock.LockWatcher
 
LruBlockCache - Class in org.apache.accumulo.core.file.blockfile.cache.lru
A block cache implementation that is memory-aware using HeapSize, memory-bound using an LRU eviction algorithm, and concurrent: backed by a ConcurrentHashMap and with a non-blocking eviction thread giving constant-time LruBlockCache.cacheBlock(java.lang.String, byte[], boolean) and LruBlockCache.getBlock(java.lang.String) operations.
LruBlockCache(LruBlockCacheConfiguration) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Default constructor.
LruBlockCache.CacheStats - Class in org.apache.accumulo.core.file.blockfile.cache.lru
 
LruBlockCacheConfiguration - Class in org.apache.accumulo.core.file.blockfile.cache.lru
 
LruBlockCacheConfiguration(BlockCacheManager.Configuration, CacheType) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
LruBlockCacheConfiguration.Builder - Class in org.apache.accumulo.core.file.blockfile.cache.lru
 
LruBlockCacheManager - Class in org.apache.accumulo.core.file.blockfile.cache.lru
 
LruBlockCacheManager() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheManager
 
Lz4 - Class in org.apache.accumulo.core.spi.file.rfile.compression
 
Lz4() - Constructor for class org.apache.accumulo.core.spi.file.rfile.compression.Lz4
 
Lzo - Class in org.apache.accumulo.core.spi.file.rfile.compression
 
Lzo() - Constructor for class org.apache.accumulo.core.spi.file.rfile.compression.Lzo
 

M

main(String[]) - Static method in class org.apache.accumulo.core.conf.ClientConfigGenerate
Generates markdown and config files for Accumulo client properties.
main(String[]) - Static method in class org.apache.accumulo.core.conf.cluster.ClusterConfigParser
 
main(String[]) - Static method in class org.apache.accumulo.core.conf.ConfigurationDocGen
Generates documentation for accumulo.properties 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.CreateEmpty
 
main(String[]) - Static method in class org.apache.accumulo.core.file.rfile.GenerateSplits
 
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.TCompactionType
 
MAJOR_COMPACTION - org.apache.accumulo.core.file.FilePrefix
 
MAJOR_COMPACTION_ALL_FILES - org.apache.accumulo.core.file.FilePrefix
 
majors - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
majors - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
MAJORS - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
MAJORS - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
makePlan(CompactionPlanner.PlanningParameters) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionPlanner
Plan what work a compaction service should do.
makePlan(CompactionPlanner.PlanningParameters) - Method in class org.apache.accumulo.core.spi.compaction.DefaultCompactionPlanner
 
MANAGER - org.apache.accumulo.core.lock.ServiceLockData.ThriftService
 
MANAGER - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
MANAGER_BULK_TIMEOUT - org.apache.accumulo.core.conf.Property
 
MANAGER_CLIENTPORT - org.apache.accumulo.core.conf.Property
 
MANAGER_FATE_METRICS_MIN_UPDATE_INTERVAL - org.apache.accumulo.core.conf.Property
 
MANAGER_FATE_THREADPOOL_SIZE - org.apache.accumulo.core.conf.Property
 
MANAGER_LEASE_RECOVERY_WAITING_PERIOD - org.apache.accumulo.core.conf.Property
 
MANAGER_METADATA_SUSPENDABLE - org.apache.accumulo.core.conf.Property
 
MANAGER_MINTHREADS - org.apache.accumulo.core.conf.Property
 
MANAGER_MINTHREADS_TIMEOUT - org.apache.accumulo.core.conf.Property
 
MANAGER_PREFIX - org.apache.accumulo.core.conf.Property
 
MANAGER_RECOVERY_DELAY - org.apache.accumulo.core.conf.Property
 
MANAGER_RECOVERY_WAL_EXISTENCE_CACHE_TIME - org.apache.accumulo.core.conf.Property
 
MANAGER_RENAME_THREADS - org.apache.accumulo.core.conf.Property
 
MANAGER_STARTUP_TSERVER_AVAIL_MAX_WAIT - org.apache.accumulo.core.conf.Property
 
MANAGER_STARTUP_TSERVER_AVAIL_MIN_COUNT - org.apache.accumulo.core.conf.Property
 
MANAGER_STATUS_THREAD_POOL_SIZE - org.apache.accumulo.core.conf.Property
 
MANAGER_TABLET_BALANCER - org.apache.accumulo.core.conf.Property
 
MANAGER_TABLET_GROUP_WATCHER_INTERVAL - org.apache.accumulo.core.conf.Property
 
MANAGER_THREADCHECK - org.apache.accumulo.core.conf.Property
 
MANAGER_WAL_CLOSER_IMPLEMENTATION - org.apache.accumulo.core.conf.Property
 
ManagerClient<C extends org.apache.thrift.TServiceClient> - Interface in org.apache.accumulo.core.rpc.clients
 
ManagerClientService - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService
 
ManagerClientService.AsyncClient - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.getActiveTservers_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.getDelegationToken_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.getManagerStats_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.initiateFlush_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.modifyNamespaceProperties_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.modifySystemProperties_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.modifyTableProperties_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.removeNamespaceProperty_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.removeSystemProperty_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.removeTableProperty_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.reportSplitExtent_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.reportTabletStatus_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.setManagerGoalState_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.setNamespaceProperty_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.setSystemProperty_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.setTableProperty_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.shutdown_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.shutdownTabletServer_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.waitForBalance_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncClient.waitForFlush_call - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncIface - Interface in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.getActiveTservers<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.getDelegationToken<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.getManagerStats<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.initiateFlush<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.modifyNamespaceProperties<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.modifySystemProperties<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.modifyTableProperties<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.removeNamespaceProperty<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.removeSystemProperty<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.removeTableProperty<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.reportSplitExtent<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.reportTabletStatus<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.setManagerGoalState<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.setNamespaceProperty<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.setSystemProperty<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.setTableProperty<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.shutdown<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.shutdownTabletServer<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.waitForBalance<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.AsyncProcessor.waitForFlush<I extends ManagerClientService.AsyncIface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Client - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Client.Factory - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.getActiveTservers_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.getActiveTservers_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.getActiveTservers_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.getActiveTservers_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.getDelegationToken_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.getDelegationToken_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.getDelegationToken_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.getDelegationToken_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.getManagerStats_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.getManagerStats_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.getManagerStats_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.getManagerStats_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.Iface - Interface in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.initiateFlush_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.initiateFlush_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.initiateFlush_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.initiateFlush_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.modifyNamespaceProperties_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.modifyNamespaceProperties_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.modifyNamespaceProperties_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.modifyNamespaceProperties_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.modifySystemProperties_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.modifySystemProperties_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.modifySystemProperties_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.modifySystemProperties_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.modifyTableProperties_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.modifyTableProperties_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.modifyTableProperties_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.modifyTableProperties_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.Processor<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.getActiveTservers<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.getDelegationToken<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.getManagerStats<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.initiateFlush<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.modifyNamespaceProperties<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.modifySystemProperties<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.modifyTableProperties<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.removeNamespaceProperty<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.removeSystemProperty<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.removeTableProperty<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.reportSplitExtent<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.reportTabletStatus<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.setManagerGoalState<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.setNamespaceProperty<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.setSystemProperty<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.setTableProperty<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.shutdown<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.shutdownTabletServer<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.waitForBalance<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.Processor.waitForFlush<I extends ManagerClientService.Iface> - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.removeNamespaceProperty_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.removeNamespaceProperty_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.removeNamespaceProperty_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.removeNamespaceProperty_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.removeSystemProperty_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.removeSystemProperty_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.removeSystemProperty_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.removeSystemProperty_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.removeTableProperty_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.removeTableProperty_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.removeTableProperty_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.removeTableProperty_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.reportSplitExtent_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.reportSplitExtent_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.reportTabletStatus_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.reportTabletStatus_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.setManagerGoalState_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.setManagerGoalState_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.setManagerGoalState_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.setManagerGoalState_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.setNamespaceProperty_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.setNamespaceProperty_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.setNamespaceProperty_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.setNamespaceProperty_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.setSystemProperty_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.setSystemProperty_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.setSystemProperty_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.setSystemProperty_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.setTableProperty_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.setTableProperty_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.setTableProperty_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.setTableProperty_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.shutdown_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.shutdown_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.shutdown_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.shutdown_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.shutdownTabletServer_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.shutdownTabletServer_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.shutdownTabletServer_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.shutdownTabletServer_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.waitForBalance_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.waitForBalance_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.waitForBalance_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.waitForBalance_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.waitForFlush_args - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.waitForFlush_args._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerClientService.waitForFlush_result - Class in org.apache.accumulo.core.manager.thrift
 
ManagerClientService.waitForFlush_result._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerGoalState - Enum in org.apache.accumulo.core.manager.thrift
 
ManagerMonitorInfo - Class in org.apache.accumulo.core.manager.thrift
 
ManagerMonitorInfo() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
ManagerMonitorInfo(Map<String, TableInfo>, List<TabletServerStatus>, Map<String, Byte>, ManagerState, ManagerGoalState, int, Set<String>, List<DeadServer>, List<BulkImportStatus>) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
ManagerMonitorInfo(ManagerMonitorInfo) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
Performs a deep copy on other.
ManagerMonitorInfo._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ManagerState - Enum in org.apache.accumulo.core.manager.thrift
 
ManagerThriftClient - Class in org.apache.accumulo.core.rpc.clients
 
MAP_CONCURRENCY_PROPERTY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
MAP_LOAD_PROPERTY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
mapConcurrencyLevel(int) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
MapCounter<KT> - Class in org.apache.accumulo.core.util
A Map counter for counting with longs or integers.
MapCounter() - Constructor for class org.apache.accumulo.core.util.MapCounter
 
mapLoadFactor(float) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
mapNames(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
Mapping(KeyExtent, Bulk.Files) - Constructor for class org.apache.accumulo.core.clientImpl.bulk.Bulk.Mapping
 
mark(int) - Method in class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
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
 
markSupported() - Method in class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
markSupported() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
markSupported() - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
 
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
 
max() - Method in interface org.apache.accumulo.core.spi.common.Stats
 
max() - Method in class org.apache.accumulo.core.util.MapCounter
 
max() - Method in class org.apache.accumulo.core.util.Stat
 
MAX__KEY_SIZE_EXCEEDED_VIOLATION - Static variable in class org.apache.accumulo.core.data.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_CKL_DEFAULT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
 
MAX_COUNTER_DEFAULT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
 
MAX_COUNTER_LEN_OPT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
A configuration option for specifying the maximum length of an individual counter key.
MAX_COUNTERS_OPT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
A configuration option for specifying the maximum number of unique counters an instance of this summarizer should track.
MAX_DATA_TO_PRINT - Static variable in class org.apache.accumulo.core.Constants
 
MAX_LOOPS - org.apache.accumulo.core.manager.thrift.ManagerClientService.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
Maximize the Start Key timestamp.
maxLoops - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
maxRetries(long) - Method in interface org.apache.accumulo.core.util.Retry.NeedsRetries
 
maxSize - Static variable in class org.apache.accumulo.core.data.constraints.DefaultKeySizeConstraint
 
maxThreads - Variable in class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
 
maxVersions - Variable in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
maxWait(long, TimeUnit) - Method in interface org.apache.accumulo.core.util.Retry.NeedsMaxWait
 
mean() - Method in interface org.apache.accumulo.core.spi.common.Stats
 
mean() - Method in class org.apache.accumulo.core.util.Stat
 
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
 
MEMORY - org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock.BlockPriority
Block from in-memory store
MEMORY_FACTOR_PROPERTY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
MemoryConverter() - Constructor for class org.apache.accumulo.core.util.Merge.MemoryConverter
 
memoryFactor(float) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
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.clientImpl.TableOperationsImpl
 
merge(List<CompletableFuture<T>>, BiFunction<T, T, T>, Supplier<T>) - Static method in class org.apache.accumulo.core.util.CompletableFutureUtil
 
merge(Map<String, Long>, Map<String, Long>) - Method in interface org.apache.accumulo.core.client.summary.Summarizer.Combiner
This method should merge the statistics in the second map into the first map.
merge(AccumuloClient, String, List<Merge.Size>, int) - Method in class org.apache.accumulo.core.util.Merge
 
merge(BatchWriterConfig) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Merge this BatchWriterConfig with another.
merge(ConditionalWriterConfig) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Merge this ConditionalWriterConfig with another.
merge(SummaryCollection, SummarizerFactory) - Method in class org.apache.accumulo.core.summary.SummaryCollection
 
merge(SummaryCollection, SummaryCollection, SummarizerFactory) - Static method in class org.apache.accumulo.core.summary.SummaryCollection
 
Merge - Class in org.apache.accumulo.core.util
 
Merge() - Constructor for class org.apache.accumulo.core.util.Merge
 
MERGE - org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
MERGE - org.apache.accumulo.core.tabletserver.thrift.TCompactionType
 
Merge.MemoryConverter - Class in org.apache.accumulo.core.util
 
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.iteratorsImpl.IteratorConfigUtil
 
mergeMany(AccumuloClient, 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(AccumuloClient, String, List<Merge.Size>, int) - Method in class org.apache.accumulo.core.util.Merge
 
mergomatic(AccumuloClient, String, Text, Text, long, boolean) - Method in class org.apache.accumulo.core.util.Merge
 
message - Variable in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
message(String, Object...) - Method in class org.apache.accumulo.core.util.Merge
 
MESSAGE - org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
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.
MetaBlockDoesNotExist(UncheckedIOException) - Constructor for exception org.apache.accumulo.core.file.rfile.bcfile.MetaBlockDoesNotExist
 
metaCache - Variable in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
METADATA - org.apache.accumulo.core.clientImpl.TabletType
 
METADATA - org.apache.accumulo.core.metadata.schema.Ample.DataLevel
 
METADATA_FILE_ENTRY - org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
 
metadataEntry - Variable in class org.apache.accumulo.core.gc.ReferenceFile
 
metadataFileEntry - Variable in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
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.clientImpl.thrift.ClientService.authenticate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
metaDataMap - Static variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
metaDataMap - Static variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
metaDataMap - Static variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
metaDataMap - Static variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
metaDataMap - Static variable in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
metaDataMap - Static variable in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
metaDataMap - Static variable in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
metaDataMap - Static variable in class org.apache.accumulo.core.dataImpl.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.manager.thrift.BulkImportStatus
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.Compacting
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.DeadServer
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
metaDataMap - Static variable in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
metaDataMap - Static variable in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
metaDataMap - Static variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
metaDataMap - Static variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
metaDataMap - Static variable in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
metaDataMap - Static variable in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
metaDataMap - Static variable in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
metaDataMap - Static variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
metaDataMap - Static variable in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
metaDataMap - Static variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
MetadataSchema - Class in org.apache.accumulo.core.metadata.schema
Describes the table schema used for metadata tables
MetadataSchema() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema
 
MetadataSchema.BlipSection - Class in org.apache.accumulo.core.metadata.schema
Holds bulk-load-in-progress processing flags
MetadataSchema.DeletesSection - Class in org.apache.accumulo.core.metadata.schema
Holds delete markers for potentially unused files/directories
MetadataSchema.DeletesSection.SkewedKeyValue - Class in org.apache.accumulo.core.metadata.schema
Value to indicate that the row has been skewed/encoded.
MetadataSchema.ExternalCompactionSection - Class in org.apache.accumulo.core.metadata.schema
 
MetadataSchema.ProblemSection - Class in org.apache.accumulo.core.metadata.schema
Holds error message processing flags
MetadataSchema.ReservedSection - Class in org.apache.accumulo.core.metadata.schema
Contains additional metadata in a reserved area not for tablets
MetadataSchema.ScanServerFileReferenceSection - Class in org.apache.accumulo.core.metadata.schema
 
MetadataSchema.TabletsSection - Class in org.apache.accumulo.core.metadata.schema
Used for storing information about tablets
MetadataSchema.TabletsSection.BulkFileColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Temporary markers that indicate a tablet loaded a bulk file
MetadataSchema.TabletsSection.ChoppedColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for indicating that the files in a tablet have been trimmed to only include data for the current tablet, so that they are safe to merge
MetadataSchema.TabletsSection.ClonedColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Temporary marker that indicates a tablet was successfully cloned
MetadataSchema.TabletsSection.CurrentLocationColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing entries created by the TServer to indicate it has loaded a tablet that it was assigned
MetadataSchema.TabletsSection.DataFileColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing files used by a tablet
MetadataSchema.TabletsSection.ExternalCompactionColumnFamily - Class in org.apache.accumulo.core.metadata.schema
 
MetadataSchema.TabletsSection.FutureLocationColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing the assigned location
MetadataSchema.TabletsSection.LastLocationColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing last location, as a hint for assignment
MetadataSchema.TabletsSection.LogColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing write-ahead log entries
MetadataSchema.TabletsSection.ScanFileColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing the set of files scanned with an isolated scanner, to prevent them from being deleted
MetadataSchema.TabletsSection.ServerColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for recording information used by the TServer
MetadataSchema.TabletsSection.SuspendLocationColumn - Class in org.apache.accumulo.core.metadata.schema
Column family for storing suspension location, as a demand for assignment.
MetadataSchema.TabletsSection.TabletColumnFamily - Class in org.apache.accumulo.core.metadata.schema
Column family for storing the tablet information needed by clients
MetadataServicer - Class in org.apache.accumulo.core.metadata
Provides a consolidated API for handling table metadata
MetadataServicer() - Constructor for class org.apache.accumulo.core.metadata.MetadataServicer
 
MetadataTable - Class in org.apache.accumulo.core.metadata
 
MetadataTable() - Constructor for class org.apache.accumulo.core.metadata.MetadataTable
 
MetadataTime - Class in org.apache.accumulo.core.metadata.schema
Immutable metadata time object
MetadataTime(long, TimeType) - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataTime
 
metaTable() - Method in enum org.apache.accumulo.core.metadata.schema.Ample.DataLevel
 
MeterRegistryFactory - Interface in org.apache.accumulo.core.metrics
 
metric - Variable in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
METRICS_COMPACTOR_MAJC_STUCK - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_COMPACTOR_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_FATE_ERRORS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_FATE_OPS_ACTIVITY - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_FATE_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_FATE_TOTAL_IN_PROGRESS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_FATE_TX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_FATE_TYPE_IN_PROGRESS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_CANDIDATES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_DELETED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_ERRORS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_FINISHED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_IN_USE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_POST_OP_DURATION - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_RUN_CYCLE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_STARTED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_WAL_CANDIDATES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_WAL_DELETED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_WAL_ERRORS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_WAL_FINISHED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_WAL_IN_USE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_GC_WAL_STARTED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_LOW_MEMORY - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_MAJC_PAUSED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_MAJC_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_MAJC_QUEUED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_MAJC_RUNNING - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_MINC_PAUSED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_MINC_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_MINC_QUEUED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_MINC_RUNNING - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_PROPSTORE_EVICTION_COUNT - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_PROPSTORE_LOAD_TIMER - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_PROPSTORE_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_PROPSTORE_REFRESH_COUNT - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_PROPSTORE_REFRESH_LOAD_COUNT - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_PROPSTORE_ZK_ERROR_COUNT - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_BUSY_TIMEOUT - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_CLOSE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_CONTINUE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_OPEN_FILES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_PAUSED_FOR_MEM - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_RESULTS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_RETURN_FOR_MEM - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_START - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_TIMES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_SCAN_YIELDS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_THRIFT_EXECUTE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_THRIFT_IDLE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_THRIFT_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_ENTRIES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_HOLD - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_INGEST_BYTES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_INGEST_MUTATIONS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_MAJC_QUEUED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_MAJC_RUNNING - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_MAJC_STUCK - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_MEM_ENTRIES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_MINC_QUEUED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_MINC_RUNNING - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_MINC_TOTAL - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_QUERIES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_SCAN_RESULTS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_SCAN_RESULTS_BYTES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_SCANNED_ENTRIES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_TABLETS_FILES - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_TABLETS_LONG_ASSIGNMENTS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_TABLETS_ONLINE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_TABLETS_OPENING - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_TSERVER_TABLETS_UNOPENED - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_UPDATE_COMMIT - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_UPDATE_COMMIT_PREP - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_UPDATE_ERRORS - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_UPDATE_MUTATION_ARRAY_SIZE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_UPDATE_PREFIX - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
METRICS_UPDATE_WALOG_WRITE - Static variable in interface org.apache.accumulo.core.metrics.MetricsProducer
 
MetricsGatherer<T> - Interface in org.apache.accumulo.core.file.rfile
Interface used to gather metrics from RFiles.
MetricsProducer - Interface in org.apache.accumulo.core.metrics
Prior to 2.1.0 Accumulo used the Hadoop Metrics2 framework.
MetricsUtil - Class in org.apache.accumulo.core.metrics
 
MetricsUtil() - Constructor for class org.apache.accumulo.core.metrics.MetricsUtil
 
migrationsOut() - Method in class org.apache.accumulo.core.manager.balancer.BalanceParamsImpl
 
migrationsOut() - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer.BalanceParameters
 
MILLIS - org.apache.accumulo.core.client.admin.TimeType
This is the default.
min() - Method in interface org.apache.accumulo.core.spi.common.Stats
 
min() - Method in class org.apache.accumulo.core.util.Stat
 
MIN_FACTOR_PROPERTY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
MIN_FILES_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
minc - org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
 
MinCombiner - Class in org.apache.accumulo.core.iterators.user
A Combiner that interprets Values as Longs and returns the smallest Long among them.
MinCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.MinCombiner
 
minFactor(float) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
minimizeEndKeyTimeStamp(Range) - Static method in class org.apache.accumulo.core.iterators.IteratorUtil
Minimize the endKey Timestamp.
MINOR - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
compaction to flush a tablets memory
MINOR - org.apache.accumulo.core.tabletserver.thrift.TCompactionType
 
MINOR_COMPACTION - org.apache.accumulo.core.file.FilePrefix
 
minors - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
minors - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
MINORS - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
MINORS - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
miss() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
missassigned(KeyExtent, String, String, TServerInstance, TServerInstance, int) - Static method in class org.apache.accumulo.core.logging.TabletLogger
Called when a tablet's current assignment state does not match the goal state.
mkdirs(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Ensure the provided path exists, using persistent nodes, empty data, and the default ACL for any missing path elements.
modifyNamespaceProperties() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyNamespaceProperties
 
modifyNamespaceProperties() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyNamespaceProperties
 
modifyNamespaceProperties(TInfo, TCredentials, String, TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
modifyNamespaceProperties(TInfo, TCredentials, String, TVersionedProperties) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
modifyNamespaceProperties(TInfo, TCredentials, String, TVersionedProperties, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
modifyNamespaceProperties(TInfo, TCredentials, String, TVersionedProperties, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
modifyNamespaceProperties_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
modifyNamespaceProperties_args(TInfo, TCredentials, String, TVersionedProperties) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
modifyNamespaceProperties_args(ManagerClientService.modifyNamespaceProperties_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
Performs a deep copy on other.
modifyNamespaceProperties_call(TInfo, TCredentials, String, TVersionedProperties, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifyNamespaceProperties_call
 
modifyNamespaceProperties_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
modifyNamespaceProperties_result(ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException, ThriftConcurrentModificationException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
modifyNamespaceProperties_result(ManagerClientService.modifyNamespaceProperties_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
Performs a deep copy on other.
modifyProperties(String, Consumer<Map<String, String>>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
For a detailed overview of the behavior of this method see InstanceOperations.modifyProperties(Consumer) which operates on a different layer of properties but has the same behavior and better documentation.
modifyProperties(String, Consumer<Map<String, String>>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
For a detailed overview of the behavior of this method see InstanceOperations.modifyProperties(Consumer) which operates on a different layer of properties but has the same behavior and better documentation.
modifyProperties(String, Consumer<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
modifyProperties(String, Consumer<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
modifyProperties(Consumer<Map<String, String>>) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Modify system properties using a Consumer that accepts a mutable map containing the current system property overrides stored in ZooKeeper.
modifyProperties(Consumer<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
modifySystemProperties() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifySystemProperties
 
modifySystemProperties() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifySystemProperties
 
modifySystemProperties(TInfo, TCredentials, TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
modifySystemProperties(TInfo, TCredentials, TVersionedProperties) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
modifySystemProperties(TInfo, TCredentials, TVersionedProperties, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
modifySystemProperties(TInfo, TCredentials, TVersionedProperties, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
modifySystemProperties_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
modifySystemProperties_args(TInfo, TCredentials, TVersionedProperties) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
modifySystemProperties_args(ManagerClientService.modifySystemProperties_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
Performs a deep copy on other.
modifySystemProperties_call(TInfo, TCredentials, TVersionedProperties, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifySystemProperties_call
 
modifySystemProperties_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
modifySystemProperties_result(ThriftSecurityException, ThriftNotActiveServiceException, ThriftConcurrentModificationException, ThriftPropertyException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
modifySystemProperties_result(ManagerClientService.modifySystemProperties_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
Performs a deep copy on other.
modifyTableProperties() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyTableProperties
 
modifyTableProperties() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyTableProperties
 
modifyTableProperties(TInfo, TCredentials, String, TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
modifyTableProperties(TInfo, TCredentials, String, TVersionedProperties) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
modifyTableProperties(TInfo, TCredentials, String, TVersionedProperties, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
modifyTableProperties(TInfo, TCredentials, String, TVersionedProperties, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
modifyTableProperties_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
modifyTableProperties_args(TInfo, TCredentials, String, TVersionedProperties) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
modifyTableProperties_args(ManagerClientService.modifyTableProperties_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
Performs a deep copy on other.
modifyTableProperties_call(TInfo, TCredentials, String, TVersionedProperties, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifyTableProperties_call
 
modifyTableProperties_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
modifyTableProperties_result(ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException, ThriftConcurrentModificationException, ThriftPropertyException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
modifyTableProperties_result(ManagerClientService.modifyTableProperties_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
Performs a deep copy on other.
modulus - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
MODULUS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args._Fields
 
MONITOR_LOCK_CHECK_INTERVAL - org.apache.accumulo.core.conf.Property
 
MONITOR_PORT - org.apache.accumulo.core.conf.Property
 
MONITOR_PREFIX - org.apache.accumulo.core.conf.Property
 
MONITOR_RESOURCES_EXTERNAL - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_EXCLUDE_CIPHERS - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_INCLUDE_CIPHERS - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_INCLUDE_PROTOCOLS - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_KEYPASS - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_KEYSTORE - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_KEYSTOREPASS - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_KEYSTORETYPE - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_TRUSTSTORE - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_TRUSTSTOREPASS - org.apache.accumulo.core.conf.Property
 
MONITOR_SSL_TRUSTSTORETYPE - org.apache.accumulo.core.conf.Property
 
MonitorUtil - Class in org.apache.accumulo.core.util
 
MonitorUtil() - Constructor for class org.apache.accumulo.core.util.MonitorUtil
 
more - Variable in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
more - Variable in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
MORE - org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
MORE - org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
 
MOVING - org.apache.accumulo.core.manager.thrift.BulkImportState
 
MULTI - org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock.BlockPriority
Accessed multiple times
MULTI - org.apache.accumulo.core.spi.scan.ScanInfo.Type
A multi range scan started using a BatchScanner
MULTI_FACTOR_PROPERTY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
multiFactor(float) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
MultiIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
An iterator capable of iterating over other iterators in sorted order.
MultiIterator(List<SortedKeyValueIterator<Key, Value>>, boolean) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.MultiIterator
 
MultiIterator(List<SortedKeyValueIterator<Key, Value>>, Range) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.MultiIterator
 
MultiIterator(List<SortedKeyValueIterator<Key, Value>>, KeyExtent) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.MultiIterator
 
MultiLevelIndex - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex() - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex
 
MultiLevelIndex.BufferedWriter - Class in org.apache.accumulo.core.file.rfile
this class buffers writes to the index so that chunks of index blocks are contiguous in the file instead of having index blocks sprinkled throughout the file making scans of the entire index slow.
MultiLevelIndex.IndexEntry - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex.Reader - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex.Reader.IndexIterator - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex.Reader.Node - Class in org.apache.accumulo.core.file.rfile
 
MultiLevelIndex.Writer - Class in org.apache.accumulo.core.file.rfile
 
MultiScanResult - Class in org.apache.accumulo.core.dataImpl.thrift
 
MultiScanResult() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
MultiScanResult(List<TKeyValue>, Map<TKeyExtent, List<TRange>>, List<TKeyExtent>, TKeyExtent, TKey, boolean, boolean) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
MultiScanResult(MultiScanResult) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
Performs a deep copy on other.
MultiScanResult._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
MultiTableBatchWriter - Interface in org.apache.accumulo.core.client
This class enables efficient batch writing to multiple tables.
MultiTableBatchWriterImpl - Class in org.apache.accumulo.core.clientImpl
 
MutableByteSequence - Class in org.apache.accumulo.core.util
 
MutableByteSequence(byte[], int, int) - Constructor for class org.apache.accumulo.core.util.MutableByteSequence
 
MutableByteSequence(ByteSequence) - Constructor for class org.apache.accumulo.core.util.MutableByteSequence
 
mutate() - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
This method persist (or queues for persisting) previous put and deletes against this object.
mutate(byte[]) - Method in interface org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter.Mutator
 
mutateExisting(String, ZooReaderWriter.Mutator) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Update an existing ZK node using the provided mutator function.
mutateOrCreate(String, byte[], ZooReaderWriter.Mutator) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Create a new CreateMode.PERSISTENT ZK node with the default ACL if it does not exist.
mutateTablet(KeyExtent) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Initiates mutating a single tablets persistent metadata.
mutateTablet(KeyExtent) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletsMutator
 
mutateTablets() - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Use this when updating multiple tablets.
mutation - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
mutation - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
Mutation - Class in org.apache.accumulo.core.data
Mutation represents an action that manipulates a row in a table.
Mutation() - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
Mutation(byte[]) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
Mutation(byte[], int) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
Mutation(byte[], int, int) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
Mutation(byte[], int, int, int) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
Mutation(CharSequence) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
Mutation(CharSequence, int) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
Mutation(Mutation) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation by copying another.
Mutation(TMutation) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation from a Thrift mutation.
Mutation(Text) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
Mutation(Text, int) - Constructor for class org.apache.accumulo.core.data.Mutation
Creates a new mutation.
MUTATION - org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
 
MUTATION - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args._Fields
 
Mutation.FamilyOptions - Interface in org.apache.accumulo.core.data
Provides methods for setting the column family of a Mutation.
Mutation.MutationOptions - Interface in org.apache.accumulo.core.data
Provides methods for setting the value of a Mutation.
Mutation.QualifierOptions - Interface in org.apache.accumulo.core.data
Provides methods for setting the column qualifier of a Mutation.
Mutation.SERIALIZED_FORMAT - Enum in org.apache.accumulo.core.data
Formats available for serializing Mutations.
Mutation.TimestampOptions - Interface in org.apache.accumulo.core.data
Provides methods for setting the timestamp of a Mutation.
Mutation.VisibilityOptions - Interface in org.apache.accumulo.core.data
Provides methods for setting the column visibility of a Mutation.
mutations - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
mutations - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
MUTATIONS - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args._Fields
 
MUTATIONS - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args._Fields
 
MutationsRejectedException - Exception in org.apache.accumulo.core.client
Communicate the failed mutations of a BatchWriter back to the client.
MutationsRejectedException(AccumuloClient, List<ConstraintViolationSummary>, Map<TabletId, Set<SecurityErrorCode>>, Collection<String>, int, Throwable) - Constructor for exception org.apache.accumulo.core.client.MutationsRejectedException
Creates Mutations rejected exception

N

name - Variable in class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
 
name - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
name - Variable in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
name - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
name - Variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
name() - Method in class org.apache.accumulo.core.clientImpl.Namespace
 
NAME - org.apache.accumulo.core.manager.thrift.RecoveryStatus._Fields
 
NAME - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
NAME - org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
NAME - Static variable in class org.apache.accumulo.core.metadata.MetadataTable
 
NAME - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection.SkewedKeyValue
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ChoppedColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ClonedColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.CurrentLocationColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.DataFileColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ExternalCompactionColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.FutureLocationColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LastLocationColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LogColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ScanFileColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
 
NAME_PROPERTY - Static variable in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
NamedLikeRFile() - Constructor for class org.apache.accumulo.core.file.rfile.CreateEmpty.NamedLikeRFile
 
namedOptions - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
Namespace - Class in org.apache.accumulo.core.clientImpl
 
Namespace(String, NamespaceId) - Constructor for class org.apache.accumulo.core.clientImpl.Namespace
 
NAMESPACE_CREATE - org.apache.accumulo.core.manager.thrift.FateOperation
 
NAMESPACE_DELETE - org.apache.accumulo.core.manager.thrift.FateOperation
 
NAMESPACE_DOESNT_EXIST - org.apache.accumulo.core.client.security.SecurityErrorCode
 
NAMESPACE_DOESNT_EXIST - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
NAMESPACE_EXISTS - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
NAMESPACE_ID - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
NAMESPACE_NOTFOUND - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
NAMESPACE_RENAME - org.apache.accumulo.core.manager.thrift.FateOperation
 
NamespaceExistsException - Exception in org.apache.accumulo.core.client
Thrown when the namespace specified already exists, and it was expected that it didn't
NamespaceExistsException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.NamespaceExistsException
 
NamespaceExistsException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.NamespaceExistsException
 
NamespaceExistsException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.NamespaceExistsException
 
namespaceId - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
NamespaceId - Class in org.apache.accumulo.core.data
A strongly typed representation of a namespace ID.
namespaceIdMap() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Get a mapping of namespace name to internal namespace id.
namespaceIdMap() - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
namespaceNameExists(ClientContext, String) - Static method in class org.apache.accumulo.core.clientImpl.Namespaces
Return true if namespace name exists
NamespaceNotEmptyException - Exception in org.apache.accumulo.core.client
Thrown when the namespace specified contains tables
NamespaceNotEmptyException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
NamespaceNotEmptyException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
NamespaceNotEmptyException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotEmptyException
 
NamespaceNotFoundException - Exception in org.apache.accumulo.core.client
Thrown when the namespace specified doesn't exist when it was expected to
NamespaceNotFoundException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
NamespaceNotFoundException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
NamespaceNotFoundException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.NamespaceNotFoundException
 
namespaceOperations() - Method in interface org.apache.accumulo.core.client.AccumuloClient
Retrieves a NamespaceOperations object to perform namespace functions, such as create and delete.
namespaceOperations() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
NamespaceOperations - Interface in org.apache.accumulo.core.client.admin
Provides an API for administering namespaces All tables exist in a namespace.
NamespaceOperationsHelper - Class in org.apache.accumulo.core.clientImpl
 
NamespaceOperationsHelper() - Constructor for class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
NamespaceOperationsImpl - Class in org.apache.accumulo.core.clientImpl
 
NamespaceOperationsImpl(ClientContext, TableOperationsImpl) - Constructor for class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
NamespacePermission - Enum in org.apache.accumulo.core.security
Accumulo namespace permissions.
Namespaces - Class in org.apache.accumulo.core.clientImpl
 
Namespaces() - Constructor for class org.apache.accumulo.core.clientImpl.Namespaces
 
nbHash - Variable in class org.apache.accumulo.core.bloomfilter.Filter
The number of hash function to consider.
needsDictionary() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
needsInput() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
needsInput() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
NEGATE - Static variable in class org.apache.accumulo.core.iterators.Filter
 
NEGATE - Static variable in class org.apache.accumulo.core.iterators.user.SeekingFilter
 
NEW - org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Unseeded transaction
NEW - org.apache.accumulo.core.manager.state.tables.TableState
 
NEW_NAMESPACE_NAME - Static variable in class org.apache.accumulo.core.util.Validators
 
NEW_TABLE_NAME - Static variable in class org.apache.accumulo.core.util.Validators
 
NEW_TABLETS - org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
 
newBuffer() - Method in class org.apache.accumulo.core.client.IsolatedScanner.MemoryRowBufferFactory
 
newBuffer() - Method in interface org.apache.accumulo.core.client.IsolatedScanner.RowBufferFactory
 
newClient() - Static method in class org.apache.accumulo.core.client.Accumulo
Fluent entry point for creating an AccumuloClient.
newClientProperties() - Static method in class org.apache.accumulo.core.client.Accumulo
Fluent entry point for creating client Properties.
newColumnUpdate(byte[], byte[], byte[], boolean, long, boolean, byte[]) - Method in class org.apache.accumulo.core.data.Mutation
 
newCryptoService(String) - Method in interface org.apache.accumulo.core.spi.crypto.CryptoServiceFactory
Loads a crypto service based on the name provided.
newDeriver(Function<AccumuloConfiguration, T>) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Enables deriving an object from configuration and automatically deriving a new object any time configuration changes.
newIndexReaderBuilder() - Method in class org.apache.accumulo.core.file.FileOperations
Construct an operation object allowing one to create an index iterator for a file.
newInstance(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.crypto.CryptoFactoryLoader
Creates a new server Factory.
newReaderBuilder() - Method in class org.apache.accumulo.core.file.FileOperations
Construct an operation object allowing one to create a reader for a file.
newSampler(SamplerConfigurationImpl, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.sample.impl.SamplerFactory
 
newSampler(SamplerConfigurationImpl, AccumuloConfiguration, boolean) - Static method in class org.apache.accumulo.core.sample.impl.SamplerFactory
 
newSamplerConfig(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
newScanner() - Static method in class org.apache.accumulo.core.client.rfile.RFile
Entry point for building a new Scanner over one or more RFiles.
newScanReaderBuilder() - Method in class org.apache.accumulo.core.file.FileOperations
Construct an operation object allowing one to create a "scan" reader for a file.
NewTableConfiguration - Class in org.apache.accumulo.core.client.admin
This object stores table creation parameters.
NewTableConfiguration() - Constructor for class org.apache.accumulo.core.client.admin.NewTableConfiguration
 
newTablets - Variable in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
newWriter() - Static method in class org.apache.accumulo.core.client.rfile.RFile
Entry point for creating a new RFile writer.
newWriterBuilder() - Method in class org.apache.accumulo.core.file.FileOperations
Construct an operation object allowing one to create a writer for a file.
next() - Method in class org.apache.accumulo.core.client.RowIterator
Fetch the next row.
next() - Method in class org.apache.accumulo.core.clientImpl.bulk.LoadMappingIterator
 
next() - Method in class org.apache.accumulo.core.clientImpl.ScannerIterator
 
next() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReaderIterator
 
next() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
next() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
next() - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
next() - Method in class org.apache.accumulo.core.iterators.Combiner
 
next() - Method in class org.apache.accumulo.core.iterators.Combiner.ValueIterator
 
next() - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
next() - Method in class org.apache.accumulo.core.iterators.DevNull
 
next() - Method in class org.apache.accumulo.core.iterators.Filter
 
next() - Method in class org.apache.accumulo.core.iterators.IteratorAdapter
 
next() - Method in class org.apache.accumulo.core.iterators.OrIterator
 
next() - Method in class org.apache.accumulo.core.iterators.ServerFilter
 
next() - Method in class org.apache.accumulo.core.iterators.ServerSkippingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.SkippingIterator
 
next() - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Advances to the next K,V pair.
next() - Method in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
next() - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
next() - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.RowFilter
 
next() - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
 
next() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
next() - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
next() - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.CountingIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.HeapIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.StatsIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
next() - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
next() - Method in class org.apache.accumulo.core.metadata.schema.LinkingIterator
 
next() - Method in class org.apache.accumulo.core.util.format.AggregatingFormatter
 
next() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
next() - Method in class org.apache.accumulo.core.util.PeekingIterator
 
NEXT - org.apache.accumulo.core.iterators.user.SeekingFilter.AdvanceResult
 
NEXT_CF - org.apache.accumulo.core.iterators.user.SeekingFilter.AdvanceResult
 
NEXT_CQ - org.apache.accumulo.core.iterators.user.SeekingFilter.AdvanceResult
 
NEXT_ROW - org.apache.accumulo.core.iterators.user.SeekingFilter.AdvanceResult
 
nextArraySize(int) - Static method in class org.apache.accumulo.core.util.UnsynchronizedBuffer
Determines what next array size should be by rounding up to next power of two.
nextIndex() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
NoCompression - Class in org.apache.accumulo.core.spi.file.rfile.compression
 
NoCompression() - Constructor for class org.apache.accumulo.core.spi.file.rfile.compression.NoCompression
 
NoCryptoService - Class in org.apache.accumulo.core.spi.crypto
The default encryption strategy which does nothing.
NoCryptoService() - Constructor for class org.apache.accumulo.core.spi.crypto.NoCryptoService
 
NoCryptoServiceFactory - Class in org.apache.accumulo.core.spi.crypto
 
NoCryptoServiceFactory() - Constructor for class org.apache.accumulo.core.spi.crypto.NoCryptoServiceFactory
 
node - Variable in class org.apache.accumulo.core.fate.zookeeper.ZooUtil.LockID
 
Node(int, int) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.Node
 
Node(ColumnVisibility.NodeType, int) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.Node
 
NodeComparator(byte[]) - Constructor for class org.apache.accumulo.core.security.ColumnVisibility.NodeComparator
Creates a new comparator.
NoDeleteConstraint - Class in org.apache.accumulo.core.data.constraints
This constraint ensures mutations do not have deletes.
NoDeleteConstraint() - Constructor for class org.apache.accumulo.core.data.constraints.NoDeleteConstraint
 
NoFileDecrypter - Class in org.apache.accumulo.core.spi.crypto
 
NoFileDecrypter() - Constructor for class org.apache.accumulo.core.spi.crypto.NoFileDecrypter
 
NoFileEncrypter - Class in org.apache.accumulo.core.spi.crypto
 
NoFileEncrypter() - Constructor for class org.apache.accumulo.core.spi.crypto.NoFileEncrypter
 
NoFlushOutputStream - Class in org.apache.accumulo.core.crypto.streams
 
NoFlushOutputStream(OutputStream) - Constructor for class org.apache.accumulo.core.crypto.streams.NoFlushOutputStream
 
NONE - org.apache.accumulo.core.client.Durability
Don't bother writing mutations to the write-ahead log.
NONE - org.apache.accumulo.core.lock.ServiceLockData.ThriftService
 
NONE - org.apache.accumulo.core.tabletingest.thrift.TDurability
 
NONE - Static variable in class org.apache.accumulo.core.spi.crypto.NoCryptoServiceFactory
 
noop() - Static method in class org.apache.accumulo.core.singletons.SingletonReservation
 
NORMAL - org.apache.accumulo.core.manager.thrift.ManagerGoalState
 
NORMAL - org.apache.accumulo.core.manager.thrift.ManagerState
 
normalize(ColumnVisibility.Node, byte[]) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
 
normalize(ColumnVisibility.Node, byte[], ColumnVisibility.NodeComparator) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
 
NoSuchMetaStoreException - Exception in org.apache.accumulo.core.file
 
NoSuchMetaStoreException(String) - Constructor for exception org.apache.accumulo.core.file.NoSuchMetaStoreException
 
NoSuchMetaStoreException(String, Throwable) - Constructor for exception org.apache.accumulo.core.file.NoSuchMetaStoreException
 
NoSuchScanIDException - Exception in org.apache.accumulo.core.tabletserver.thrift
 
NoSuchScanIDException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
NoSuchScanIDException(NoSuchScanIDException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
Performs a deep copy on other.
NoSuchScanIDException._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.
not() - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
not() - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
not() - Method in class org.apache.accumulo.core.bloomfilter.Filter
Performs a logical NOT on this filter.
not() - Method in class org.apache.accumulo.core.util.Validator
Creates a new validator that is the negation of this one.
NOT_BUILTIN_NAMESPACE - Static variable in class org.apache.accumulo.core.util.Validators
 
NOT_BUILTIN_TABLE - Static variable in class org.apache.accumulo.core.util.Validators
 
NOT_METADATA_TABLE - Static variable in class org.apache.accumulo.core.util.Validators
 
NOT_ROOT_TABLE_ID - Static variable in class org.apache.accumulo.core.util.Validators
 
notFlag - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
NOTFOUND - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
NotServingTabletException - Exception in org.apache.accumulo.core.tabletserver.thrift
 
NotServingTabletException() - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
NotServingTabletException(TKeyExtent) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
NotServingTabletException(NotServingTabletException) - Constructor for exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
Performs a deep copy on other.
NotServingTabletException._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.
now() - Method in class org.apache.accumulo.core.util.OpTimer
Returns current timer elapsed time as nanoseconds.
now(TimeUnit) - Method in class org.apache.accumulo.core.util.OpTimer
Converts current timer value to specific unit.
ns - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
ns - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
ns - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
ns - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
ns - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
ns - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
ns - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
ns - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
ns - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
NS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
NS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
 
NS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
 
NS - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
NS - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
NS - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
NS - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
 
NS - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
 
NS - org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
nssi - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
nssi - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
nssi - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
nssi - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
nssi - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
nssi - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
NSSI - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result._Fields
 
NSSI - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result._Fields
 
NSSI - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result._Fields
 
NSSI - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result._Fields
 
NSSI - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
 
NSSI - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result._Fields
 
nste - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
nste - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
nste - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
nste - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
NSTE - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result._Fields
 
NSTE - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result._Fields
 
NSTE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
 
NSTE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
 
NULL_PROVIDER - Static variable in interface org.apache.accumulo.core.file.blockfile.impl.CacheProvider
 
NullRateLimiter - Class in org.apache.accumulo.core.util.ratelimit
A rate limiter which doesn't actually limit rates at all.
NullSplitter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.NullSplitter
 
NullSplitter() - Constructor for class org.apache.accumulo.core.cli.ConfigOpts.NullSplitter
 
nullText - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
NullToken - Class in org.apache.accumulo.core.client.security.tokens
 
NullToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.NullToken
 
NullType - Class in org.apache.accumulo.core.compaction
 
NullType() - Constructor for class org.apache.accumulo.core.compaction.NullType
 
num - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
num() - Method in interface org.apache.accumulo.core.spi.common.Stats
 
num() - Method in class org.apache.accumulo.core.util.Stat
 
NUM - org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
NUM_ENTRIES - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
NUMBER_OF_VIOLATING_MUTATIONS - org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
 
numberOfViolatingMutations - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
numberOfViolatingMutations - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
numBlocks - Variable in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
numBytes() - Method in class org.apache.accumulo.core.data.Mutation
Gets the total number of bytes in this mutation.
numEntries - Variable in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
numEntries - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
numFiles - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
NumUtil - Class in org.apache.accumulo.core.util
 
NumUtil() - Constructor for class org.apache.accumulo.core.util.NumUtil
 

O

OBJECT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Object overhead is minimum 2 * reference size (8 bytes on 64-bit)
obscured() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
OBSOLETE_BULK_BAD_ERROR_DIRECTORY - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
OBSOLETE_BULK_BAD_LOAD_MAPPING - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
OBSOLETE_TABLE_BULK_IMPORT - org.apache.accumulo.core.manager.thrift.FateOperation
 
OBTAIN_DELEGATION_TOKEN - org.apache.accumulo.core.security.SystemPermission
 
of(boolean, SeekingFilter.AdvanceResult) - Static method in class org.apache.accumulo.core.iterators.user.SeekingFilter.FilterResult
 
of(String) - Static method in class org.apache.accumulo.core.data.InstanceId
Get a InstanceId object for the provided canonical string.
of(String) - Static method in class org.apache.accumulo.core.data.NamespaceId
Get a NamespaceId object for the provided canonical string.
of(String) - Static method in class org.apache.accumulo.core.data.TableId
Get a TableId object for the provided canonical string.
of(String) - Static method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionId
 
of(String) - Static method in class org.apache.accumulo.core.metadata.StoredTabletFile
 
of(String) - Static method in class org.apache.accumulo.core.spi.compaction.CompactionServiceId
 
of(UUID) - Static method in class org.apache.accumulo.core.data.InstanceId
Get a InstanceId object for the provided uuid.
of(TableId) - Static method in enum org.apache.accumulo.core.metadata.schema.Ample.DataLevel
 
of(Configuration, Path) - Static method in class org.apache.accumulo.core.metadata.UnreferencedTabletFile
 
of(FileSystem, File) - Static method in class org.apache.accumulo.core.metadata.UnreferencedTabletFile
 
of(FileSystem, Path) - Static method in class org.apache.accumulo.core.metadata.UnreferencedTabletFile
 
of(Path) - Static method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
 
offline(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Initiates taking a table offline, but does not wait for action to complete
offline(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
offline(String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
offline(String, boolean) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
OFFLINE - org.apache.accumulo.core.client.admin.InitialTableState
 
OFFLINE - org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
OFFLINE - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
OFFLINE - org.apache.accumulo.core.manager.state.tables.TableState
 
OfflineScanner - Class in org.apache.accumulo.core.clientImpl
 
OfflineScanner(ClientContext, TableId, Authorizations) - Constructor for class org.apache.accumulo.core.clientImpl.OfflineScanner
 
offset - Variable in class org.apache.accumulo.core.data.ArrayByteSequence
 
offset() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
offset() - Method in class org.apache.accumulo.core.data.ByteSequence
Gets the offset for this sequence.
OK - Static variable in class org.apache.accumulo.core.util.Validator
 
OLD_EXTENT - Static variable in class org.apache.accumulo.core.metadata.RootTable
 
OLD_PREV_ROW - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
OLD_PREV_ROW_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
 
OLD_PREV_ROW_QUAL - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
A temporary field in case a split fails and we need to roll back
OLD_TABLET - org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
 
oldTablet - Variable in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
online(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Initiates bringing a table online, but does not wait for action to complete
online(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
online(String, boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
online(String, boolean) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
ONLINE - org.apache.accumulo.core.client.admin.InitialTableState
 
ONLINE - org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
ONLINE - org.apache.accumulo.core.manager.state.tables.TableState
 
ONLINE_TABLETS - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
onlineTablets - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
op - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
op - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
OP - org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
OP - org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
open() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
open() - Method in class org.apache.accumulo.core.rpc.UGIAssumingTransport
 
open(Path) - Method in interface org.apache.accumulo.core.clientImpl.bulk.BulkSerialize.Input
 
openIndex(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.FileOperations
 
openIndex(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openReader(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.FileOperations
 
openReader(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openScanReader(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.FileOperations
 
openScanReader(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
openWriter(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.FileOperations
 
openWriter(FileOperations.FileOptions) - Method in class org.apache.accumulo.core.file.rfile.RFileOperations
 
opid - Variable in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
opid - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
opid - Variable in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
opid - Variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
OPID - org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
 
OPID - org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
OPID - org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
 
OPID - org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
 
OPPORTUNISTIC - org.apache.accumulo.core.spi.scan.ScanDispatch.CacheUsage
Use data if it exists in cache, but never load data into cache.
OpportunisticBlockCache - Class in org.apache.accumulo.core.file.blockfile.impl
 
OpportunisticBlockCache(BlockCache) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.OpportunisticBlockCache
 
OPT_MAX_CF - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MAX_CF_DESC - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MAX_CQ - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MAX_CQ_DESC - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MAX_INCLUSIVE - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MAX_INCLUSIVE_DESC - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MIN_CF - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MIN_CF_DESC - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MIN_CQ - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MIN_CQ_DESC - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MIN_INCLUSIVE - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OPT_MIN_INCLUSIVE_DESC - Static variable in class org.apache.accumulo.core.iterators.user.CfCqSliceOpts
 
OpTimer - Class in org.apache.accumulo.core.util
Provides a stop watch for timing a single type of event.
OpTimer() - Constructor for class org.apache.accumulo.core.util.OpTimer
 
OptionDescriber - Interface in org.apache.accumulo.core.iterators
The OptionDescriber interface allows you to set up iterator properties interactively in the accumulo shell.
OptionDescriber.IteratorOptions - Class in org.apache.accumulo.core.iterators
 
options - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
options - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
options - Variable in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
OPTIONS - org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
 
OPTIONS - org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
OPTIONS - org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration._Fields
 
opts(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.iteratorsImpl.IteratorBuilderImpl
 
or(Filter) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
or(Filter) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
or(Filter) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Performs a logical OR between this filter and a specified filter.
or(Validator<T>) - Method in class org.apache.accumulo.core.util.Validator
Creates a new validator that is the disjunction of this one and the given one.
OR - org.apache.accumulo.core.security.ColumnVisibility.NodeType
 
OR_FIELDS - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
org.apache.accumulo.core - package org.apache.accumulo.core
 
org.apache.accumulo.core.bloomfilter - package org.apache.accumulo.core.bloomfilter
 
org.apache.accumulo.core.classloader - package org.apache.accumulo.core.classloader
 
org.apache.accumulo.core.cli - package org.apache.accumulo.core.cli
 
org.apache.accumulo.core.client - package org.apache.accumulo.core.client
 
org.apache.accumulo.core.client.admin - package org.apache.accumulo.core.client.admin
 
org.apache.accumulo.core.client.admin.compaction - package org.apache.accumulo.core.client.admin.compaction
 
org.apache.accumulo.core.client.lexicoder - package org.apache.accumulo.core.client.lexicoder
 
org.apache.accumulo.core.client.rfile - package org.apache.accumulo.core.client.rfile
 
org.apache.accumulo.core.client.sample - package org.apache.accumulo.core.client.sample
 
org.apache.accumulo.core.client.security - package org.apache.accumulo.core.client.security
 
org.apache.accumulo.core.client.security.tokens - package org.apache.accumulo.core.client.security.tokens
 
org.apache.accumulo.core.client.summary - package org.apache.accumulo.core.client.summary
 
org.apache.accumulo.core.client.summary.summarizers - package org.apache.accumulo.core.client.summary.summarizers
 
org.apache.accumulo.core.clientImpl - package org.apache.accumulo.core.clientImpl
 
org.apache.accumulo.core.clientImpl.bulk - package org.apache.accumulo.core.clientImpl.bulk
 
org.apache.accumulo.core.clientImpl.lexicoder - package org.apache.accumulo.core.clientImpl.lexicoder
 
org.apache.accumulo.core.clientImpl.thrift - package org.apache.accumulo.core.clientImpl.thrift
 
org.apache.accumulo.core.compaction - package org.apache.accumulo.core.compaction
 
org.apache.accumulo.core.compaction.thrift - package org.apache.accumulo.core.compaction.thrift
 
org.apache.accumulo.core.conf - package org.apache.accumulo.core.conf
 
org.apache.accumulo.core.conf.cluster - package org.apache.accumulo.core.conf.cluster
 
org.apache.accumulo.core.constraints - package org.apache.accumulo.core.constraints
 
org.apache.accumulo.core.crypto - package org.apache.accumulo.core.crypto
 
org.apache.accumulo.core.crypto.streams - package org.apache.accumulo.core.crypto.streams
 
org.apache.accumulo.core.data - package org.apache.accumulo.core.data
 
org.apache.accumulo.core.data.constraints - package org.apache.accumulo.core.data.constraints
 
org.apache.accumulo.core.dataImpl - package org.apache.accumulo.core.dataImpl
 
org.apache.accumulo.core.dataImpl.thrift - package org.apache.accumulo.core.dataImpl.thrift
 
org.apache.accumulo.core.fate - package org.apache.accumulo.core.fate
 
org.apache.accumulo.core.fate.zookeeper - package org.apache.accumulo.core.fate.zookeeper
 
org.apache.accumulo.core.file - package org.apache.accumulo.core.file
 
org.apache.accumulo.core.file.blockfile.cache.impl - package org.apache.accumulo.core.file.blockfile.cache.impl
 
org.apache.accumulo.core.file.blockfile.cache.lru - package org.apache.accumulo.core.file.blockfile.cache.lru
 
org.apache.accumulo.core.file.blockfile.cache.tinylfu - package org.apache.accumulo.core.file.blockfile.cache.tinylfu
 
org.apache.accumulo.core.file.blockfile.impl - package org.apache.accumulo.core.file.blockfile.impl
 
org.apache.accumulo.core.file.keyfunctor - package org.apache.accumulo.core.file.keyfunctor
 
org.apache.accumulo.core.file.rfile - package org.apache.accumulo.core.file.rfile
 
org.apache.accumulo.core.file.rfile.bcfile - package org.apache.accumulo.core.file.rfile.bcfile
 
org.apache.accumulo.core.file.streams - package org.apache.accumulo.core.file.streams
 
org.apache.accumulo.core.gc - package org.apache.accumulo.core.gc
 
org.apache.accumulo.core.gc.thrift - package org.apache.accumulo.core.gc.thrift
 
org.apache.accumulo.core.iterators - package org.apache.accumulo.core.iterators
 
org.apache.accumulo.core.iterators.user - package org.apache.accumulo.core.iterators.user
 
org.apache.accumulo.core.iteratorsImpl - package org.apache.accumulo.core.iteratorsImpl
 
org.apache.accumulo.core.iteratorsImpl.conf - package org.apache.accumulo.core.iteratorsImpl.conf
 
org.apache.accumulo.core.iteratorsImpl.system - package org.apache.accumulo.core.iteratorsImpl.system
 
org.apache.accumulo.core.lock - package org.apache.accumulo.core.lock
 
org.apache.accumulo.core.logging - package org.apache.accumulo.core.logging
This package exist to provide a central place in Accumulo's source code for important log messages.
org.apache.accumulo.core.manager.balancer - package org.apache.accumulo.core.manager.balancer
 
org.apache.accumulo.core.manager.state.tables - package org.apache.accumulo.core.manager.state.tables
 
org.apache.accumulo.core.manager.thrift - package org.apache.accumulo.core.manager.thrift
 
org.apache.accumulo.core.metadata - package org.apache.accumulo.core.metadata
 
org.apache.accumulo.core.metadata.schema - package org.apache.accumulo.core.metadata.schema
 
org.apache.accumulo.core.metrics - package org.apache.accumulo.core.metrics
 
org.apache.accumulo.core.rpc - package org.apache.accumulo.core.rpc
 
org.apache.accumulo.core.rpc.clients - package org.apache.accumulo.core.rpc.clients
 
org.apache.accumulo.core.sample.impl - package org.apache.accumulo.core.sample.impl
 
org.apache.accumulo.core.schema - package org.apache.accumulo.core.schema
 
org.apache.accumulo.core.security - package org.apache.accumulo.core.security
 
org.apache.accumulo.core.securityImpl.thrift - package org.apache.accumulo.core.securityImpl.thrift
 
org.apache.accumulo.core.singletons - package org.apache.accumulo.core.singletons
 
org.apache.accumulo.core.spi - package org.apache.accumulo.core.spi
This package provides a place for plugin interfaces intended for Accumulo users to implement.
org.apache.accumulo.core.spi.balancer - package org.apache.accumulo.core.spi.balancer
 
org.apache.accumulo.core.spi.balancer.data - package org.apache.accumulo.core.spi.balancer.data
 
org.apache.accumulo.core.spi.balancer.util - package org.apache.accumulo.core.spi.balancer.util
 
org.apache.accumulo.core.spi.cache - package org.apache.accumulo.core.spi.cache
 
org.apache.accumulo.core.spi.common - package org.apache.accumulo.core.spi.common
 
org.apache.accumulo.core.spi.compaction - package org.apache.accumulo.core.spi.compaction
This package provides a place for plugin interfaces related to executing compactions.
org.apache.accumulo.core.spi.crypto - package org.apache.accumulo.core.spi.crypto
 
org.apache.accumulo.core.spi.file.rfile.compression - package org.apache.accumulo.core.spi.file.rfile.compression
 
org.apache.accumulo.core.spi.fs - package org.apache.accumulo.core.spi.fs
 
org.apache.accumulo.core.spi.scan - package org.apache.accumulo.core.spi.scan
 
org.apache.accumulo.core.summary - package org.apache.accumulo.core.summary
 
org.apache.accumulo.core.tablet.thrift - package org.apache.accumulo.core.tablet.thrift
 
org.apache.accumulo.core.tabletingest.thrift - package org.apache.accumulo.core.tabletingest.thrift
 
org.apache.accumulo.core.tabletscan.thrift - package org.apache.accumulo.core.tabletscan.thrift
 
org.apache.accumulo.core.tabletserver.log - package org.apache.accumulo.core.tabletserver.log
 
org.apache.accumulo.core.tabletserver.thrift - package org.apache.accumulo.core.tabletserver.thrift
 
org.apache.accumulo.core.trace - package org.apache.accumulo.core.trace
 
org.apache.accumulo.core.util - package org.apache.accumulo.core.util
 
org.apache.accumulo.core.util.cleaner - package org.apache.accumulo.core.util.cleaner
 
org.apache.accumulo.core.util.compaction - package org.apache.accumulo.core.util.compaction
 
org.apache.accumulo.core.util.format - package org.apache.accumulo.core.util.format
 
org.apache.accumulo.core.util.json - package org.apache.accumulo.core.util.json
 
org.apache.accumulo.core.util.ratelimit - package org.apache.accumulo.core.util.ratelimit
 
org.apache.accumulo.core.util.tables - package org.apache.accumulo.core.util.tables
 
org.apache.accumulo.core.util.threads - package org.apache.accumulo.core.util.threads
 
org.apache.accumulo.core.volume - package org.apache.accumulo.core.volume
 
OrIterator - Class in org.apache.accumulo.core.iterators
An iterator that provides a sorted-iteration of column qualifiers for a set of column families in a row.
OrIterator() - Constructor for class org.apache.accumulo.core.iterators.OrIterator
 
OrIterator.TermSource - Class in org.apache.accumulo.core.iterators
 
OS_LOAD - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
osLoad - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
OTHER - org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
 
OUTPUT_BLOCK_SIZE_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
OUTPUT_COMPRESSION_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
OUTPUT_FILE - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
OUTPUT_FILE - org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
OUTPUT_HDFS_BLOCK_SIZE_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
OUTPUT_INDEX_BLOCK_SIZE_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
OUTPUT_REPLICATION_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
outputFile - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
outputFile - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
outputShellVariables(Map<String, String>, PrintStream) - Static method in class org.apache.accumulo.core.conf.cluster.ClusterConfigParser
 
outputStream - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
overlapping(byte[], byte[]) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableRangeOptions
 
overlapping(Text, boolean, Text) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
overlapping(Text, boolean, Text) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableRangeOptions
When startRowInclusive is true limits to tablets that overlap the range [startRow,endRow].
overlapping(Text, Text) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
overlapping(Text, Text) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableRangeOptions
Limit to tablets that overlap the range (startRow, endRow].
overlaps(KeyExtent) - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
overRange(Range) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
overRange(Range) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.RangeOptions
 
overRange(Range, Set<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.file.FileOperations.ScanReaderBuilder
Set the range over which the constructed iterator will search.
override(CompactionConfigurer.InputParameters) - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer
 
override(CompactionConfigurer.InputParameters) - Method in class org.apache.accumulo.core.client.admin.compaction.CompressionConfigurer
 
override(CompactionConfigurer.InputParameters) - Method in class org.apache.accumulo.core.compaction.ShellCompactCommandConfigurer
 
overrideCurrentTime(long) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
overrides - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
Overrides(Map<String, String>) - Constructor for class org.apache.accumulo.core.client.admin.compaction.CompactionConfigurer.Overrides
 
OVERRIDES - org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
OVERWRITE - org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeExistsPolicy
 
overwritePersistentData(String, byte[], int) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Overwrite a persistent node if the data version matches.

P

Pair<A,​B> - Class in org.apache.accumulo.core.util
 
Pair(A, B) - Constructor for class org.apache.accumulo.core.util.Pair
 
PairLexicoder<A extends Comparable<A>,​B extends Comparable<B>> - Class in org.apache.accumulo.core.client.lexicoder
This class is a lexicoder that sorts a ComparablePair.
PairLexicoder(Lexicoder<A>, Lexicoder<B>) - Constructor for class org.apache.accumulo.core.client.lexicoder.PairLexicoder
 
parent - Variable in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
parse(byte[]) - Static method in class org.apache.accumulo.core.lock.ServiceLockData
 
parse(String) - Static method in class org.apache.accumulo.core.conf.PropertyType.PortRange
 
parse(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataTime
Creates a MetadataTime object from a string
parse(String, ParsePosition) - Method in class org.apache.accumulo.core.util.format.FormatterConfig.DefaultDateFormat
 
parseAddress(String, boolean) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
parseAddress(String, int) - Static method in class org.apache.accumulo.core.util.AddressUtil
 
parseArgs(String, String[], Object...) - Method in class org.apache.accumulo.core.cli.ClientOpts
 
parseArgs(String, String[], Object...) - Method in class org.apache.accumulo.core.cli.ConfigOpts
 
parseArgs(String, String[], Object...) - Method in class org.apache.accumulo.core.cli.Help
 
parseConfiguration(String) - Static method in class org.apache.accumulo.core.conf.cluster.ClusterConfigParser
 
parseDocID(Key) - Static method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
parseIterConf(IteratorUtil.IteratorScope, List<IterInfo>, Map<String, Map<String, String>>, AccumuloConfiguration) - Static method in class org.apache.accumulo.core.iteratorsImpl.IteratorConfigUtil
 
parsePath(Path) - Static method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
 
parseTidFromUserInput(String) - Static method in class org.apache.accumulo.core.fate.FateTxId
 
PART_NEXT_KEY - org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
PART_NEXT_KEY_INCLUSIVE - org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
PART_SCAN - org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
PartialKey - Enum in org.apache.accumulo.core.data
Specifications for part of a Key.
partition(List<Mutation>, PreAllocatedArray<List<Mutation>>) - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.Partitioner
 
PartitionedMutation(byte[], List<ColumnUpdate>) - Constructor for class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
 
Partitioner(PreAllocatedArray<Map<ByteSequence, MutableLong>>) - Constructor for class org.apache.accumulo.core.util.LocalityGroupUtil.Partitioner
 
partNextKey - Variable in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
partNextKeyInclusive - Variable in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
partScan - Variable in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
password - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
password - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
password - Variable in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
PASSWORD - org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
PASSWORD - org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
 
PASSWORD - org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
 
PasswordConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.PasswordConverter
 
PasswordToken - Class in org.apache.accumulo.core.client.security.tokens
 
PasswordToken() - Constructor for class org.apache.accumulo.core.client.security.tokens.PasswordToken
Constructor for use with Writable.
PasswordToken(byte[]) - Constructor for class org.apache.accumulo.core.client.security.tokens.PasswordToken
Constructs a token from a copy of the password.
PasswordToken(CharSequence) - Constructor for class org.apache.accumulo.core.client.security.tokens.PasswordToken
Constructs a token from a copy of the password.
PasswordToken(ByteBuffer) - Constructor for class org.apache.accumulo.core.client.security.tokens.PasswordToken
Constructs a token from a copy of the password.
path - Variable in class org.apache.accumulo.core.fate.zookeeper.ZooUtil.LockID
 
path - Variable in class org.apache.accumulo.core.metadata.AbstractTabletFile
 
path(String) - Static method in class org.apache.accumulo.core.fate.zookeeper.FateLock
 
path(String) - Static method in class org.apache.accumulo.core.lock.ServiceLock
 
PATH - org.apache.accumulo.core.conf.PropertyType
 
pathToCacheId(Path) - Static method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile
 
peek() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
peek() - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
peek() - Method in class org.apache.accumulo.core.util.PeekingIterator
 
PeekingIterator<E> - Class in org.apache.accumulo.core.util
 
PeekingIterator() - Constructor for class org.apache.accumulo.core.util.PeekingIterator
Creates an uninitialized instance.
PeekingIterator(Iterator<E>) - Constructor for class org.apache.accumulo.core.util.PeekingIterator
 
peekPrevious() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
PER_BLOCK_OVERHEAD - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
permission - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
permission - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
permission - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
permission - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
permission - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
permission - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
PERMISSION - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
PERMISSION - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
 
PERMISSION - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
PERMISSION - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
PERMISSION - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
 
PERMISSION - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
PERMISSION - org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
PERMISSION_DENIED - org.apache.accumulo.core.client.security.SecurityErrorCode
 
PERMISSION_DENIED - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
PERMISSIONHANDLER_FAILED - org.apache.accumulo.core.client.security.SecurityErrorCode
 
PERMISSIONHANDLER_FAILED - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
PerTableCryptoServiceFactory - Class in org.apache.accumulo.core.spi.crypto
A factory that loads a CryptoService based on TableId.
PerTableCryptoServiceFactory() - Constructor for class org.apache.accumulo.core.spi.crypto.PerTableCryptoServiceFactory
 
ping() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.ping
 
ping() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.ping
 
ping(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Throws an exception if a tablet server can not be contacted.
ping(String) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
ping(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
ping(TCredentials) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
ping(TCredentials, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
ping(TCredentials, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
ping_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
ping_args(ClientService.ping_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
Performs a deep copy on other.
ping_args(TCredentials) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
ping_call(TCredentials, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.ping_call
 
ping_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
ping_result(ClientService.ping_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
Performs a deep copy on other.
ping_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
plan(LoadPlan) - Method in interface org.apache.accumulo.core.client.admin.TableOperations.ImportMappingOptions
Load files in the directory to the row ranges specified in the plan.
plan(LoadPlan) - Method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
PluginConfig - Class in org.apache.accumulo.core.client.admin
Encapsulates the configuration of an Accumulo server side plugin, which consist of a class name and options.
PluginConfig(String) - Constructor for class org.apache.accumulo.core.client.admin.PluginConfig
 
PluginConfig(String, Map<String, String>) - Constructor for class org.apache.accumulo.core.client.admin.PluginConfig
 
PluginConfigData() - Constructor for class org.apache.accumulo.core.clientImpl.UserCompactionUtils.PluginConfigData
 
PluginEnvironment - Interface in org.apache.accumulo.core.client
This interface exposes Accumulo system level information to plugins in a stable manner.
PluginEnvironment.Configuration - Interface in org.apache.accumulo.core.client
 
pop(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
pop(long) - Method in interface org.apache.accumulo.core.fate.TStore
Remove the last pushed operation from the given transaction.
pop(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
PORT - org.apache.accumulo.core.conf.PropertyType
 
PortRange(String) - Constructor for class org.apache.accumulo.core.conf.PropertyType.PortRange
 
position() - Method in class org.apache.accumulo.core.file.streams.RateLimitedOutputStream
 
PreAllocatedArray<T> - Class in org.apache.accumulo.core.util
An ArrayList implementation that represents a type-safe pre-allocated array.
PreAllocatedArray(int) - Constructor for class org.apache.accumulo.core.util.PreAllocatedArray
Creates an instance of the given capacity, with all elements initialized to null
PreferredVolumeChooser - Class in org.apache.accumulo.core.spi.fs
A RandomVolumeChooser that selects preferred volumes to use from the provided volume options.
PreferredVolumeChooser() - Constructor for class org.apache.accumulo.core.spi.fs.PreferredVolumeChooser
 
prefix(CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all rows beginning with a prefix.
prefix(CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column families beginning with a prefix within a given row.
prefix(CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column qualifiers beginning with a prefix within a given row and column family.
prefix(CharSequence, CharSequence, CharSequence, CharSequence) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column visibilities beginning with a prefix within a given row, column family, and column qualifier.
prefix(Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all rows beginning with a prefix.
prefix(Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column families beginning with a prefix within a given row.
prefix(Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column qualifiers beginning with a prefix within a given row and column family.
prefix(Text, Text, Text, Text) - Static method in class org.apache.accumulo.core.data.Range
Returns a Range that covers all column visibilities beginning with a prefix within a given row, column family, and column qualifier.
PREFIX - org.apache.accumulo.core.conf.PropertyType
 
PREFIX - Static variable in class org.apache.accumulo.core.logging.Logging
Prefix for all log messages in logical logging namespaces.
prefixChild(String) - Method in interface org.apache.accumulo.core.volume.Volume
Convert the given child path into a Path that is relative to the base path for this Volume.
prefixChild(String) - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
prepareDataBlock() - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Create a Data Block and obtain an output stream for adding data into the block.
prepareMetaBlock(String) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Create a Meta Block and obtain an output stream for adding data into the block.
prepDelete(TStore<T>, ZooReaderWriter, ServiceLock.ServiceLockPath, String) - Method in class org.apache.accumulo.core.fate.AdminUtil
 
prepFail(TStore<T>, ZooReaderWriter, ServiceLock.ServiceLockPath, String) - Method in class org.apache.accumulo.core.fate.AdminUtil
 
prettyPrint() - Method in class org.apache.accumulo.core.data.Mutation
Creates a multi-lined, human-readable String for this mutation.
PREV_END_ROW - org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
 
PREV_ROW - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
PREV_ROW_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
 
PREV_ROW_QUAL - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
README : very important that prevRow sort last to avoid race conditions between garbage collector and split this needs to sort after everything else for that tablet
prevEndRow - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
prevEndRow() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Return the previous extent's end row
previous() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
previousIndex() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
primary(CharSequence) - Method in interface org.apache.accumulo.core.client.AccumuloClient.SaslOptions
Build with Kerberos Server Primary
primary(CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
principal - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
principal - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
principal - Variable in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
principal - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
principal - Variable in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
PRINCIPAL - org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
 
PRINCIPAL - org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
 
print(ReadOnlyTStore<T>, ZooReader, ServiceLock.ServiceLockPath, Formatter, Set<Long>, EnumSet<ReadOnlyTStore.TStatus>) - Method in class org.apache.accumulo.core.fate.AdminUtil
 
print(RFile.Reader, PrintStream) - Static method in class org.apache.accumulo.core.summary.SummaryReader
 
printableValues() - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Returns a list of printable permission values.
printableValues() - Static method in enum org.apache.accumulo.core.security.SystemPermission
Returns a list of printable permission values.
printableValues() - Static method in enum org.apache.accumulo.core.security.TablePermission
Returns a list of printable permission values.
printAll(ReadOnlyTStore<T>, ZooReader, ServiceLock.ServiceLockPath) - Method in class org.apache.accumulo.core.fate.AdminUtil
 
PrintBCInfo - Class in org.apache.accumulo.core.file.rfile.bcfile
 
PrintBCInfo(String[]) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.PrintBCInfo
 
printIndex(String, PrintStream) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
printInfo(boolean) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
PrintInfo - Class in org.apache.accumulo.core.file.rfile
 
PrintInfo() - Constructor for class org.apache.accumulo.core.file.rfile.PrintInfo
 
printMetaBlockInfo() - Method in class org.apache.accumulo.core.file.rfile.bcfile.PrintBCInfo
 
printMetrics(boolean, String, PrintStream) - Method in interface org.apache.accumulo.core.file.rfile.MetricsGatherer
Print the results of the metrics gathering by locality group in the format: Metric name Number of keys Percentage of keys Number of blocks Percentage of blocks
printMetrics(boolean, String, PrintStream) - Method in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
printStat(Stat) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
For debug: print the ZooKeeper Stat with value labels for a more user friendly string.
prioritizerClass - Variable in class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
 
prioritizerOpts - Variable in class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
 
priority - Variable in class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
 
priority - Variable in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
priority - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
priority - Variable in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
priority - Variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
PRIORITY - org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
 
PRIORITY - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args._Fields
 
PRIORITY - org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
 
PRIORITY - org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
PRIVATE - Static variable in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
 
ProblemSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.ProblemSection
 
PROCEED_ZERO_NO_SUMMARY_OPT - Static variable in class org.apache.accumulo.core.client.admin.compaction.TooManyDeletesSelector
 
PROCEED_ZERO_NO_SUMMARY_OPT_DEFAULT - Static variable in class org.apache.accumulo.core.client.admin.compaction.TooManyDeletesSelector
 
process(WatchedEvent) - Method in class org.apache.accumulo.core.lock.ServiceLock
 
PROCESS - org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator.Behavior
 
processFiles(Gatherer.FileSystemResolver, Map<String, List<TRowRange>>, BlockCache, BlockCache, Cache<String, Long>, ExecutorService) - Method in class org.apache.accumulo.core.summary.Gatherer
This method will read summaries from a set of files.
PROCESSING - org.apache.accumulo.core.manager.thrift.BulkImportState
 
Processor(I) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor
 
Processor(I) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor
 
processPartition(ExecutorService, int, int) - Method in class org.apache.accumulo.core.summary.Gatherer
This methods reads a subset of file paths into memory and groups them by location.
PROFILES_DEFAULT - Static variable in class org.apache.accumulo.core.spi.scan.ConfigurableScanServerSelector
 
progress - Variable in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
progress - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
PROGRESS - org.apache.accumulo.core.manager.thrift.RecoveryStatus._Fields
 
PROPAGATE_DELETES - org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
propagateDeletes - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
properties - Variable in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
properties - Variable in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
properties() - Method in interface org.apache.accumulo.core.client.AccumuloClient
 
properties() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
Properties() - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
PROPERTIES - org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
 
PROPERTIES - org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
 
property - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
property - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
property - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
property - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
property - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
property - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
property - Variable in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
Property - Enum in org.apache.accumulo.core.conf
 
PROPERTY - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
 
PROPERTY - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
 
PROPERTY - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
 
PROPERTY - org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
PROPERTY - org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
 
PROPERTY - org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
PROPERTY - org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
 
PROPERTY_EXCLUDE_PREFIX - Static variable in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
PROPERTY_PREFIX - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
PropertyRenamer(Predicate<String>, UnaryOperator<String>) - Constructor for class org.apache.accumulo.core.conf.DeprecatedPropertyUtil.PropertyRenamer
 
PropertyType - Enum in org.apache.accumulo.core.conf
Types of Property values.
PropertyType.PortRange - Class in org.apache.accumulo.core.conf
 
protocolFactory() - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
An instance of TraceProtocolFactory
PUBLIC - Static variable in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
 
push(long, Repo<T>) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
push(long, Repo<T>) - Method in interface org.apache.accumulo.core.fate.TStore
Update the given transaction with the next operation
push(long, Repo<T>) - Method in class org.apache.accumulo.core.fate.ZooStore
 
put(byte[]) - Method in interface org.apache.accumulo.core.data.Mutation.MutationOptions
 
put(byte[], byte[], byte[]) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(byte[], byte[], long, byte[]) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(byte[], byte[], ColumnVisibility, byte[]) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(byte[], byte[], ColumnVisibility, long, byte[]) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(CharSequence) - Method in interface org.apache.accumulo.core.data.Mutation.MutationOptions
 
put(CharSequence, CharSequence, long, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(CharSequence, CharSequence, long, Value) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(CharSequence, CharSequence, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(CharSequence, CharSequence, Value) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(CharSequence, CharSequence, ColumnVisibility, long, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(CharSequence, CharSequence, ColumnVisibility, long, Value) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(CharSequence, CharSequence, ColumnVisibility, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(CharSequence, CharSequence, ColumnVisibility, Value) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(String, char[]) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
put(String, CharSequence) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
put(ByteBuffer) - Method in interface org.apache.accumulo.core.data.Mutation.MutationOptions
 
put(Map<String, String>, Map<String, String>, String) - Method in enum org.apache.accumulo.core.compaction.CompactionSettings
 
put(Mutation, Value) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
put(Value) - Method in interface org.apache.accumulo.core.data.Mutation.MutationOptions
 
put(Text) - Method in interface org.apache.accumulo.core.data.Mutation.MutationOptions
 
put(Text, Text, long, Value) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(Text, Text, Value) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(Text, Text, ColumnVisibility, long, Value) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
put(Text, Text, ColumnVisibility, Value) - Method in class org.apache.accumulo.core.data.Mutation
Puts a modification in this mutation.
putAll(Map<? extends String, ? extends char[]>) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
putAllStrings(Map<String, ? extends CharSequence>) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
putBulkFile(ReferencedTabletFile, long) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putChopped() - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putCompactionId(long) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putDelete(byte[], byte[]) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(byte[], byte[], long) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(byte[], byte[], ColumnVisibility) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(byte[], byte[], ColumnVisibility, long) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(CharSequence, CharSequence) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(CharSequence, CharSequence, long) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(CharSequence, CharSequence, ColumnVisibility) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(CharSequence, CharSequence, ColumnVisibility, long) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(Mutation) - Method in class org.apache.accumulo.core.util.ColumnFQ
 
putDelete(Text, Text) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(Text, Text, long) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(Text, Text, ColumnVisibility) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDelete(Text, Text, ColumnVisibility, long) - Method in class org.apache.accumulo.core.data.Mutation
Puts a deletion in this mutation.
putDirName(String) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putEphemeralData(String, byte[]) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Create an ephemeral node with the default ACL
putEphemeralSequential(String, byte[]) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Create an ephemeral sequential node with the default ACL
putExternalCompaction(ExternalCompactionId, ExternalCompactionMetadata) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putExternalCompactionFinalStates(Collection<ExternalCompactionFinalState>) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
 
putFile(ReferencedTabletFile, DataFileValue) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putFile(StoredTabletFile, DataFileValue) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putFlushId(long) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putGcCandidates(TableId, Collection<StoredTabletFile>) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
 
putGcFileAndDirCandidates(TableId, Collection<ReferenceFile>) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Unlike Ample.putGcCandidates(TableId, Collection) this takes file and dir GC candidates.
putLocation(TabletMetadata.Location) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putPersistentData(String, byte[], ZooUtil.NodeExistsPolicy) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Create a persistent node with the default ACL
putPersistentData(String, byte[], ZooUtil.NodeExistsPolicy, List<ACL>) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Create a persistent node with the provided ACLs
putPersistentSequential(String, byte[]) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Create a persistent sequential node with the default ACL
putPrevEndRow(Text) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putPrivatePersistentData(String, byte[], ZooUtil.NodeExistsPolicy) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Create a persistent node with the private ACL
putScan(StoredTabletFile) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putScanServerFileReferences(Collection<ScanServerRefTabletFile>) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Insert ScanServer references to Tablet files
putSuspension(TServerInstance, long) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putTime(MetadataTime) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putToAuthorizationFailures(TKeyExtent, SecurityErrorCode) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
putToBadTServers(String, byte) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
putToBatch(TKeyExtent, List<TRange>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
putToCompactions(String, TExternalCompaction) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
putToExecutionHints(String, String) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
putToExecutionHints(String, String) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
putToFailedExtents(TKeyExtent, long) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
putToFailures(TKeyExtent, List<TRange>) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
putToFiles(String, List<TRowRange>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
putToFiles(TKeyExtent, Map<String, DataFileInfo>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
putToHeaders(String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
putToMutations(TKeyExtent, List<TConditionalMutation>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
putToOptions(String, String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
putToOptions(String, String) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
putToOptions(String, String) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
putToOverrides(String, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
putToProperties(String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
putToProperties(String, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
putToSsio(String, Map<String, String>) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
putToSsio(String, Map<String, String>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
putToSsio(String, Map<String, String>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
putToSsio(String, Map<String, String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
putToSuccess(String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
putToSummary(String, long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
putToTableMap(String, TableInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
putToTableMap(String, TableInfo) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
putToUpdates(long, TCompactionStatusUpdate) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
putWal(LogEntry) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 
putZooLock(ServiceLock) - Method in interface org.apache.accumulo.core.metadata.schema.Ample.TabletMutator
 

Q

qop - Variable in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
qop(CharSequence) - Method in interface org.apache.accumulo.core.client.AccumuloClient.SaslOptions
Build with SASL quality of protection
qop(CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
qualified(String) - Static method in class org.apache.accumulo.core.util.tables.TableNameUtil
 
qualified(String, String) - Static method in class org.apache.accumulo.core.util.tables.TableNameUtil
 
qualifier(byte[]) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnQualifierStep
Set the column qualifier of the Key that this builder will build to the parameter.
qualifier(byte[]) - Method in interface org.apache.accumulo.core.data.Mutation.QualifierOptions
 
qualifier(byte[], int, int) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnQualifierStep
Set the column qualifier of the Key that this builder will build to the parameter.
qualifier(CharSequence) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnQualifierStep
Set the column qualifier of the Key that this builder will build to the parameter.
qualifier(CharSequence) - Method in interface org.apache.accumulo.core.data.Mutation.QualifierOptions
 
qualifier(ByteBuffer) - Method in interface org.apache.accumulo.core.data.Mutation.QualifierOptions
 
qualifier(Text) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnQualifierStep
Set the column qualifier of the Key that this builder will build to the parameter.
qualifier(Text) - Method in interface org.apache.accumulo.core.data.Mutation.QualifierOptions
 
qualify(String) - Static method in class org.apache.accumulo.core.util.tables.TableNameUtil
 
QUERY_BYTE_RATE - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
QUERY_RATE - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
QUERY_RATE - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
queryByteRate - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
queryRate - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
queryRate - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
queue - Variable in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
QUEUE - org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
 
QUEUE_NAME - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
QUEUE_NAME - org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
 
QUEUE_NAME - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args._Fields
 
QUEUE_SUM_DEV - org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
QUEUE_TIME - org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
queued - Variable in class org.apache.accumulo.core.manager.thrift.Compacting
 
QUEUED - org.apache.accumulo.core.client.admin.ScanState
 
QUEUED - org.apache.accumulo.core.manager.thrift.Compacting._Fields
 
QUEUED - org.apache.accumulo.core.tabletscan.thrift.ScanState
 
queueName - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
queueName - Variable in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
queueName - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
queueName - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
queueSumDev - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
queueTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
quote(byte[]) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
Properly quotes terms in a column visibility expression.
quote(String) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
Properly quotes terms in a column visibility expression.

R

RANDOM - Static variable in class org.apache.accumulo.core.util.LazySingletons
A SecureRandom instance created with the default constructor.
RandomVolumeChooser - Class in org.apache.accumulo.core.spi.fs
A VolumeChooser that selects a volume at random from the list of provided volumes.
RandomVolumeChooser() - Constructor for class org.apache.accumulo.core.spi.fs.RandomVolumeChooser
 
range - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
range - Variable in class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
range - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
Range - Class in org.apache.accumulo.core.data
This class is used to specify a range of Accumulo keys.
Range() - Constructor for class org.apache.accumulo.core.data.Range
Creates a range that goes from negative to positive infinity
Range(CharSequence) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range that covers an entire row.
Range(CharSequence, boolean, CharSequence, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow to endRow.
Range(CharSequence, CharSequence) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow inclusive to endRow inclusive.
Range(Key, boolean, boolean, Key, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from start to stop.
Range(Key, boolean, Key, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startKey to endKey.
Range(Key, Key) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startKey inclusive to endKey inclusive.
Range(Key, Key, boolean, boolean, boolean, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from start to stop.
Range(Range) - Constructor for class org.apache.accumulo.core.data.Range
Copies a range.
Range(TRange) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from a Thrift range.
Range(Text) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range that covers an entire row.
Range(Text, boolean, Text, boolean) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow to endRow.
Range(Text, Text) - Constructor for class org.apache.accumulo.core.data.Range
Creates a range from startRow inclusive to endRow inclusive.
RANGE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
RateLimitedInputStream - Class in org.apache.accumulo.core.file.streams
A decorator for an InputStream which limits the rate at which reads are performed.
RateLimitedInputStream(StreamType, RateLimiter) - Constructor for class org.apache.accumulo.core.file.streams.RateLimitedInputStream
 
RateLimitedOutputStream - Class in org.apache.accumulo.core.file.streams
A decorator for OutputStream which limits the rate at which data may be written.
RateLimitedOutputStream(FSDataOutputStream, RateLimiter) - Constructor for class org.apache.accumulo.core.file.streams.RateLimitedOutputStream
 
rateLimiter - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
rateLimiter(RateLimiter) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
RateLimiter - Interface in org.apache.accumulo.core.util.ratelimit
 
read() - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryOptions
Reads summary data from file.
read() - Method in class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
read() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
read() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionInputStream
 
read() - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
 
read() - Method in class org.apache.accumulo.core.file.streams.RateLimitedInputStream
 
read(byte[]) - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
 
read(byte[], int, int) - Method in class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
read(byte[], int, int) - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
read(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionInputStream
 
read(byte[], int, int) - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
 
read(byte[], int, int) - Method in class org.apache.accumulo.core.file.streams.RateLimitedInputStream
 
read(byte[], int, int) - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
read(DataInputStream) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
read(DataInputStream) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.FixedLongArrayEncoder
 
read(DataInputStream) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.VarLongArrayEncoder
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
read(TProtocol) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
read(TProtocol) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
read(TProtocol) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
read(TProtocol) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
read(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
read(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
read(TProtocol) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
read(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
read(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
read(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
read(TProtocol) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
read(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
read(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
read(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
read(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
read(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
read(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
read(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
read(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
READ - org.apache.accumulo.core.security.NamespacePermission
 
READ - org.apache.accumulo.core.security.TablePermission
 
READAHEAD_THRESHOLD - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
readaheadThreshold - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
readAll(byte[], int, int) - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
readBoolean() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
Reads a Boolean value from this reader's buffer.
readBytes(byte[]) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
Reads bytes from this reader's buffer, filling the given byte array.
readConsistency(Ample.ReadConsistency) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
readConsistency(Ample.ReadConsistency) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.Options
Controls how the data is read.
Reader(byte[]) - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
Creates a new reader.
Reader(byte[], InputStreamType, Configuration, CryptoService) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
Reader(InputStreamType, long, Configuration, CryptoService) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
Reader(ByteBuffer) - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
Creates a new reader.
Reader(CachableBlockFile.CachableBuilder) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
Reader(CachableBlockFile.CachableBuilder) - Constructor for class org.apache.accumulo.core.file.rfile.RFile.Reader
 
Reader(CachableBlockFile.Reader) - Constructor for class org.apache.accumulo.core.file.rfile.RFile.Reader
 
Reader(CachableBlockFile.Reader, int) - Constructor for class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
Reader(FileSKVIterator, AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
ReaderBuilder() - Constructor for class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
 
readFields(DataInput) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
readFields(DataInput) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
readFields(DataInput) - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.IteratorSetting
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
readFields(DataInput) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
readFields(DataInput) - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
readFields(DataInput) - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Column
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Key
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Mutation
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Range
 
readFields(DataInput) - Method in class org.apache.accumulo.core.data.Value
 
readFields(DataInput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
readFields(DataInput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
readFields(DataInput) - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
readFields(DataInput) - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
readFrom(DataInput) - Static method in class org.apache.accumulo.core.dataImpl.KeyExtent
Create a KeyExtent from a serialized form.
readInt() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
Reads an integer value from this reader's buffer.
readLimiter(RateLimiter) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachableBuilder
 
readLoadMapping(String, TableId, BulkSerialize.Input) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkSerialize
Read Json array of Bulk.Mapping into LoadMappingIterator
readLock() - Method in class org.apache.accumulo.core.fate.zookeeper.DistributedReadWriteLock
 
readLong() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
Reads a long value from this reader's buffer.
ReadOnlyRepo<T> - Interface in org.apache.accumulo.core.fate
Read only access to a repeatable persisted operation.
ReadOnlyTStore<T> - Interface in org.apache.accumulo.core.fate
Read only access to a Transaction Store.
ReadOnlyTStore.TStatus - Enum in org.apache.accumulo.core.fate
Possible operational status codes.
readParams(DataInputStream) - Static method in class org.apache.accumulo.core.crypto.CryptoUtils
Read the decryption parameters from the DataInputStream
readRenameMap(String, BulkSerialize.Input) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkSerialize
Reads the serialized rename file.
readString(DataInput) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Read a String as a VInt n, followed by n Bytes in Text format.
readTablet(KeyExtent, Ample.ReadConsistency, TabletMetadata.ColumnType...) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Read a single tablets metadata.
readTablet(KeyExtent, Ample.ReadConsistency, TabletMetadata.ColumnType...) - Method in class org.apache.accumulo.core.metadata.schema.AmpleImpl
 
readTablet(KeyExtent, TabletMetadata.ColumnType...) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Read a single tablets metadata.
readTablets() - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Entry point for reading multiple tablets' metadata.
readTablets() - Method in class org.apache.accumulo.core.metadata.schema.AmpleImpl
 
readVInt() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
Reads an integer value from this reader's buffer, assuming the integer was encoded as a variable-length list of bytes.
readVInt(DataInput) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Decoding the variable-length integer.
readVLong() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Reader
Reads a long value from this reader's buffer, assuming the long was encoded as a variable-length list of bytes.
readVLong(DataInput) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Decoding the variable-length integer.
reason - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
REASON - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
receive(List<Map.Entry<Key, Value>>) - Method in interface org.apache.accumulo.core.clientImpl.TabletServerBatchReaderIterator.ResultReceiver
 
RECOMPUTE_INTERVAL - Static variable in class org.apache.accumulo.core.spi.fs.SpaceAwareVolumeChooser
 
recordSize(AtomicLong) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock
 
recovered(KeyExtent, List<LogEntry>, long, long) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
recovering(KeyExtent, List<LogEntry>) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
recoverLock(DistributedReadWriteLock.QueueLock, byte[]) - Static method in class org.apache.accumulo.core.fate.zookeeper.DistributedReadWriteLock
 
RECOVERY - org.apache.accumulo.core.spi.crypto.CryptoEnvironment.Scope
 
RECOVERY_DIR - Static variable in class org.apache.accumulo.core.Constants
 
RECOVERY_NAME_PROP - Static variable in class org.apache.accumulo.core.spi.crypto.PerTableCryptoServiceFactory
 
RecoveryStatus - Class in org.apache.accumulo.core.manager.thrift
 
RecoveryStatus() - Constructor for class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
RecoveryStatus(String, int, double) - Constructor for class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
RecoveryStatus(RecoveryStatus) - Constructor for class org.apache.accumulo.core.manager.thrift.RecoveryStatus
Performs a deep copy on other.
RecoveryStatus._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
recs - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
RECS - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
RECS_IN_MEMORY - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
recsInMemory - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
recursiveCopyPersistentOverwrite(String, String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
Recursively copy any persistent data from the source to the destination, using the default ACL to create any missing nodes and skipping over any ephemeral data.
recursiveDelete(String, ZooUtil.NodeMissingPolicy) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
This method will delete a node and all its children.
recursiveDelete(ZooKeeper, String, ZooUtil.NodeMissingPolicy) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil
This method will delete a node and all its children.
recv_authenticate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_authenticateUser() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_beginFateOperation() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
recv_cancel() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
recv_cancel() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
recv_cancelFateOperation() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
recv_changeAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_changeLocalUserPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_checkClass() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_checkNamespaceClass() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_checkTableClass() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_closeMultiScan() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
recv_closeUpdate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
recv_compactionCompleted() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
recv_compactionFailed() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
recv_conditionalUpdate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
recv_continueMultiScan() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
recv_continueScan() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
recv_contiuneGetSummaries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_createLocalUser() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_dropLocalUser() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_executeFateOperation() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
recv_fails() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
recv_finishFateOperation() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
recv_getActiveCompactions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
recv_getActiveCompactions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_getActiveLogs() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_getActiveScans() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
recv_getActiveTservers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_getCompactionJob() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
recv_getCompactionQueueInfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_getCompletedCompactions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
recv_getConfiguration() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getDelegationToken() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_getDiskUsage() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getHistoricalStats() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_getInstanceId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getManagerStats() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_getNamespaceConfiguration() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getNamespaceProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getRootTabletLocation() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getRunningCompaction() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
recv_getRunningCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
recv_getRunningCompactions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
recv_getStatus() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
recv_getSystemProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getTableConfiguration() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getTableProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getTabletServerStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_getTabletStats() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_getUserAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getVersionedNamespaceProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getVersionedSystemProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getVersionedTableProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_getZooKeepers() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_grantNamespacePermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_grantSystemPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_grantTablePermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_halt() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_hasNamespacePermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_hasSystemPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_hasTablePermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_initiateFlush() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_invalidateConditionalUpdate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
recv_isActive() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_listLocalUsers() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_modifyNamespaceProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_modifySystemProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_modifyTableProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_ping() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_removeNamespaceProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_removeSystemProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_removeTableProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_reserveCompactionJob() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_revokeNamespacePermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_revokeSystemPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_revokeTablePermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
recv_setManagerGoalState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_setNamespaceProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_setSystemProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_setTableProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_shutdown() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_shutdownTabletServer() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_splitTablet() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
recv_startConditionalUpdate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
recv_startGetSummaries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_startGetSummariesForPartition() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_startGetSummariesFromFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
recv_startMultiScan() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
recv_startScan() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
recv_startUpdate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
recv_success() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
recv_throwsError() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
recv_update() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
recv_updateCompactionStatus() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
recv_waitForBalance() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
recv_waitForFateOperation() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
recv_waitForFlush() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
reduce(Key, Iterator<Value>) - Method in class org.apache.accumulo.core.iterators.Combiner
Reduces a list of Values into a single Value.
reduce(Key, Iterator<Value>) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
REDUCE_ON_FULL_COMPACTION_ONLY_OPTION - Static variable in class org.apache.accumulo.core.iterators.Combiner
 
Reference - Interface in org.apache.accumulo.core.gc
A GC reference used for collecting files and directories into a single stream.
REFERENCE - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
Reference size is 8 bytes on 64-bit, 4 bytes on 32-bit
ReferenceDirectory - Class in org.apache.accumulo.core.gc
A GC reference to a Tablet directory, like t-0003.
ReferenceDirectory(TableId, String) - Constructor for class org.apache.accumulo.core.gc.ReferenceDirectory
 
ReferencedTabletFile - Class in org.apache.accumulo.core.metadata
Object representing a tablet file that may exist in the metadata table.
ReferencedTabletFile(Path) - Constructor for class org.apache.accumulo.core.metadata.ReferencedTabletFile
Construct new tablet file using a Path.
ReferencedTabletFile.FileParts - Class in org.apache.accumulo.core.metadata
 
ReferenceFile - Class in org.apache.accumulo.core.gc
A GC reference used for streaming and delete markers.
ReferenceFile(TableId, String) - Constructor for class org.apache.accumulo.core.gc.ReferenceFile
 
REGEX_PROPERTY - Static variable in class org.apache.accumulo.core.spi.balancer.RegexGroupBalancer
 
RegExFilter - Class in org.apache.accumulo.core.iterators.user
A Filter that matches entries based on Java regular expressions.
RegExFilter() - Constructor for class org.apache.accumulo.core.iterators.user.RegExFilter
 
RegexGroupBalancer - Class in org.apache.accumulo.core.spi.balancer
A GroupBalancer that groups tablets using a configurable regex.
RegexGroupBalancer(TableId) - Constructor for class org.apache.accumulo.core.spi.balancer.RegexGroupBalancer
 
register(SingletonService) - Static method in class org.apache.accumulo.core.singletons.SingletonManager
Register a static singleton that should be disabled and enabled as needed.
registerBase64TypeAdapter(GsonBuilder) - Static method in class org.apache.accumulo.core.util.json.ByteArrayToBase64TypeAdapter
Register ByteArrayToBase64TypeAdapter for handling byte[] types on an existing GsonBuilder
registerMetrics(MeterRegistry) - Method in interface org.apache.accumulo.core.metrics.MetricsProducer
Build Micrometer Meter objects and register them with the registry
registerMetrics(MetricsGatherer<?>) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
Method that registers the given MetricsGatherer.
reinit(Configuration) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
REJECTED - org.apache.accumulo.core.client.ConditionalWriter.Status
conditions were not met and mutation was not written
REJECTED - org.apache.accumulo.core.dataImpl.thrift.TCMStatus
 
RelativeKey - Class in org.apache.accumulo.core.file.rfile
 
RelativeKey() - Constructor for class org.apache.accumulo.core.file.rfile.RelativeKey
This constructor is used when one needs to read from an input stream
RelativeKey(Key, Key) - Constructor for class org.apache.accumulo.core.file.rfile.RelativeKey
This constructor is used when constructing a key for writing to an output stream
RelativeKey.SkippR - Class in org.apache.accumulo.core.file.rfile
 
release(ZooReaderWriter, String, String) - Static method in class org.apache.accumulo.core.fate.zookeeper.ZooReservation
 
remainder - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
REMAINDER - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args._Fields
 
remove() - Method in class org.apache.accumulo.core.client.RowIterator
Unsupported.
remove() - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReaderIterator
 
remove() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
remove() - Method in class org.apache.accumulo.core.iterators.Combiner.ValueIterator
This method is unsupported in this iterator.
remove() - Method in class org.apache.accumulo.core.iterators.IteratorAdapter
 
remove() - Method in class org.apache.accumulo.core.util.format.DefaultFormatter
 
remove() - Method in class org.apache.accumulo.core.util.PeekingIterator
 
remove(Object) - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
REMOVE_PROPERTY - org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
removeBulkLoadEntries(TableId, long, Text, Text) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Remove all the Bulk Load transaction ids from a given table's metadata
removeBulkLoadInProgressFlag(String) - Method in interface org.apache.accumulo.core.metadata.schema.Ample
Remove a Bulk Load In Progress flag from the metadata table.
removeConstraint(String, int) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Remove a constraint from a namespace.
removeConstraint(String, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Remove a constraint from a table.
removeConstraint(String, int) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
removeConstraint(String, int) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
removeEntry(long) - Method in interface org.apache.accumulo.core.fate.zookeeper.DistributedReadWriteLock.QueueLock
 
removeEntry(long) - Method in class org.apache.accumulo.core.fate.zookeeper.FateLock
 
removeIterator(String, String, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Remove an iterator from a namespace by name.
removeIterator(String, String, EnumSet<IteratorUtil.IteratorScope>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Remove an iterator from a table by name.
removeIterator(String, String, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
removeIterator(String, String, EnumSet<IteratorUtil.IteratorScope>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
removeLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.removeLogs
 
removeLogs() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.removeLogs
 
removeLogs(TInfo, TCredentials, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
removeLogs(TInfo, TCredentials, List<String>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
removeLogs(TInfo, TCredentials, List<String>, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
removeLogs(TInfo, TCredentials, List<String>, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
removeLogs_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
removeLogs_args(TInfo, TCredentials, List<String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
removeLogs_args(TabletServerClientService.removeLogs_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
Performs a deep copy on other.
removeLogs_call(TInfo, TCredentials, List<String>, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.removeLogs_call
 
removeNamespaceProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeNamespaceProperty
 
removeNamespaceProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeNamespaceProperty
 
removeNamespaceProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
removeNamespaceProperty(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
removeNamespaceProperty(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
removeNamespaceProperty(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
removeNamespaceProperty_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
removeNamespaceProperty_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
removeNamespaceProperty_args(ManagerClientService.removeNamespaceProperty_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
Performs a deep copy on other.
removeNamespaceProperty_call(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeNamespaceProperty_call
 
removeNamespaceProperty_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
removeNamespaceProperty_result(ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
removeNamespaceProperty_result(ManagerClientService.removeNamespaceProperty_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
Performs a deep copy on other.
removeOption(String) - Method in class org.apache.accumulo.core.client.IteratorSetting
Remove an option from the iterator.
removeProperty(String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Removes a system property from zookeeper.
removeProperty(String) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
removeProperty(String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Removes a property from a namespace.
removeProperty(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Removes a property from a table.
removeProperty(String, String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
removeProperty(String, String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
removeScanIterator(String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Remove an iterator from the list of iterators.
removeScanIterator(String) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
removeSummarizers(String, Predicate<SummarizerConfiguration>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Removes summary generation for this table for the matching summarizers.
removeSummarizers(String, Predicate<SummarizerConfiguration>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
removeSystemProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeSystemProperty
 
removeSystemProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeSystemProperty
 
removeSystemProperty(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
removeSystemProperty(TInfo, TCredentials, String) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
removeSystemProperty(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
removeSystemProperty(TInfo, TCredentials, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
removeSystemProperty_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
removeSystemProperty_args(TInfo, TCredentials, String) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
removeSystemProperty_args(ManagerClientService.removeSystemProperty_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
Performs a deep copy on other.
removeSystemProperty_call(TInfo, TCredentials, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeSystemProperty_call
 
removeSystemProperty_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
removeSystemProperty_result(ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
removeSystemProperty_result(ManagerClientService.removeSystemProperty_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
Performs a deep copy on other.
removeTableProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeTableProperty
 
removeTableProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeTableProperty
 
removeTableProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
removeTableProperty(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
removeTableProperty(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
removeTableProperty(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
removeTableProperty_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
removeTableProperty_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
removeTableProperty_args(ManagerClientService.removeTableProperty_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
Performs a deep copy on other.
removeTableProperty_call(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeTableProperty_call
 
removeTableProperty_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
removeTableProperty_result(ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
removeTableProperty_result(ManagerClientService.removeTableProperty_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
Performs a deep copy on other.
removeTTL(IteratorSetting, IteratorSetting.Column) - Static method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
A convenience method for removing an age off threshold for a column.
rename(String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Rename a namespace
rename(String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Rename a table
rename(String, String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
rename(String, String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
RENAME - org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
renamePrefix(String, String) - Static method in class org.apache.accumulo.core.conf.DeprecatedPropertyUtil.PropertyRenamer
 
renamers - Static variable in class org.apache.accumulo.core.conf.DeprecatedPropertyUtil
Ordered list of renamers
replaceColumnFamily(Key, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with all parts (including delete flag) coming from originalKey but use newColFam as the column family.
replaceColumnQualifier(Key, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with all parts (including delete flag) coming from originalKey but use newColQual as the column qualifier.
replaceColumnVisibility(Key, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with all parts (including delete flag) coming from originalKey but use newColVis as the column visibility.
replacedBy() - Method in enum org.apache.accumulo.core.conf.Property
Gets the property in which the tagged property is replaced by.
replaceKeyParts(Key, Text, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with a column qualifier, and column visibility.
replaceKeyParts(Key, Text, Text, Text) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Make a new key with a column family, column qualifier, and column visibility.
replaceLockData(ServiceLockData) - Method in class org.apache.accumulo.core.lock.ServiceLock
 
Repo<T> - Interface in org.apache.accumulo.core.fate
Repeatable persisted operation
report() - Method in class org.apache.accumulo.core.iteratorsImpl.system.StatsIterator
 
report() - Method in interface org.apache.accumulo.core.spi.balancer.util.ThrottledBalancerProblemReporter.Problem
 
report() - Method in class org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory.SharedRateLimiter
Report the current throughput and usage of this rate limiter to the debug log.
reportProblem(ThrottledBalancerProblemReporter.Problem) - Method in class org.apache.accumulo.core.spi.balancer.util.ThrottledBalancerProblemReporter
Reports a balance problem.
reportSplitExtent() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportSplitExtent
 
reportSplitExtent() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportSplitExtent
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
reportSplitExtent(TInfo, TCredentials, String, TabletSplit, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
reportSplitExtent_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
reportSplitExtent_args(TInfo, TCredentials, String, TabletSplit) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
reportSplitExtent_args(ManagerClientService.reportSplitExtent_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
Performs a deep copy on other.
reportSplitExtent_call(TInfo, TCredentials, String, TabletSplit, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.reportSplitExtent_call
 
reportTabletStatus() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportTabletStatus
 
reportTabletStatus() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportTabletStatus
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
reportTabletStatus_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
reportTabletStatus_args(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
reportTabletStatus_args(ManagerClientService.reportTabletStatus_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
Performs a deep copy on other.
reportTabletStatus_call(TInfo, TCredentials, String, TabletLoadState, TKeyExtent, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.reportTabletStatus_call
 
request - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
request - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
request - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
REQUEST - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args._Fields
 
REQUEST - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args._Fields
 
REQUEST - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args._Fields
 
REQUEST_TIME - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args._Fields
 
requestCount() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache.CacheStats
 
requestCount() - Method in interface org.apache.accumulo.core.spi.cache.BlockCache.Stats
Returns the number of times the lookup methods have returned either a cached or uncached value.
requestTime - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
REQUIRED_SAMPLER_OPTIONS - Static variable in class org.apache.accumulo.core.client.sample.AbstractHashSampler
 
requireNotDeleted(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
requireNotOffline(TableId, String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
requireTableExists(TableId, String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
ReqVisFilter - Class in org.apache.accumulo.core.iterators.user
A Filter that matches entries with a non-empty ColumnVisibility.
ReqVisFilter() - Constructor for class org.apache.accumulo.core.iterators.user.ReqVisFilter
 
reseek(Key) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
reserve() - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
reserve() - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Reserve a transaction that is IN_PROGRESS or FAILED_IN_PROGRESS.
reserve() - Method in class org.apache.accumulo.core.fate.ZooStore
 
reserve(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
reserve(long) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Reserve the specific tid.
reserve(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
reserveCompactionJob() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.reserveCompactionJob
 
reserveCompactionJob() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.reserveCompactionJob
 
reserveCompactionJob(TInfo, TCredentials, String, long, String, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
reserveCompactionJob(TInfo, TCredentials, String, long, String, String) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
reserveCompactionJob(TInfo, TCredentials, String, long, String, String, AsyncMethodCallback<TExternalCompactionJob>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
reserveCompactionJob(TInfo, TCredentials, String, long, String, String, AsyncMethodCallback<TExternalCompactionJob>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
reserveCompactionJob_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
reserveCompactionJob_args(TInfo, TCredentials, String, long, String, String) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
reserveCompactionJob_args(TabletServerClientService.reserveCompactionJob_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
Performs a deep copy on other.
reserveCompactionJob_call(TInfo, TCredentials, String, long, String, String, AsyncMethodCallback<TExternalCompactionJob>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.reserveCompactionJob_call
 
reserveCompactionJob_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
reserveCompactionJob_result(TabletServerClientService.reserveCompactionJob_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
Performs a deep copy on other.
reserveCompactionJob_result(TExternalCompactionJob, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
RESERVED_PREFIX - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema
 
ReservedSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.ReservedSection
 
reset() - Method in class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
reset() - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
reset() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
reset() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
reset() - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
 
reset() - Method in class org.apache.accumulo.core.util.OpTimer
Stops timer instance and current elapsed time to 0.
resetState() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionInputStream
 
resetState() - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionOutputStream
 
resizePool(ThreadPoolExecutor, IntSupplier, String) - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
Resize ThreadPoolExecutor based on current value of maxThreads
resizePool(ThreadPoolExecutor, AccumuloConfiguration, Property) - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
Resize ThreadPoolExecutor based on current value of Property p
resolve(Property, Property...) - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
Given a property that is not deprecated and an ordered list of deprecated properties, determine which one to use based on which is set by the user in the configuration.
resolveDurabilty(Durability, Durability) - Static method in class org.apache.accumulo.core.clientImpl.DurabilityImpl
 
resolveFS(Logger, Configuration, Path) - Static method in class org.apache.accumulo.core.file.rfile.PrintInfo
 
RESPONSE_TIME - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
responseTime - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
result - Variable in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
result - Variable in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
Result(Exception, ConditionalMutation, String) - Constructor for class org.apache.accumulo.core.client.ConditionalWriter.Result
 
Result(ConditionalWriter.Status, ConditionalMutation, String) - Constructor for class org.apache.accumulo.core.client.ConditionalWriter.Result
 
RESULT - org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
 
RESULT - org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
 
results - Variable in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
results - Variable in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
RESULTS - org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
 
RESULTS - org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticate
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.authenticateUser
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeAuthorizations
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.changeLocalUserPassword
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkClass
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkNamespaceClass
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.checkTableClass
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.createLocalUser
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.dropLocalUser
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getConfiguration
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getDiskUsage
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getInstanceId
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceConfiguration
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getNamespaceProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getRootTabletLocation
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getSystemProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableConfiguration
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getTableProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getUserAuthorizations
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedNamespaceProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedSystemProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getVersionedTableProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.getZooKeepers
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantNamespacePermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantSystemPermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.grantTablePermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasNamespacePermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasSystemPermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.hasTablePermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.isActive
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.listLocalUsers
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.ping
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeNamespacePermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeSystemPermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeTablePermission
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.fails
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.success
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.throwsError
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.cancel
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionCompleted
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.compactionFailed
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompactionJob
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getCompletedCompactions
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.getRunningCompactions
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.updateCompactionStatus
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.cancel
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getActiveCompactions
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompaction
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Processor.getRunningCompactionId
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Processor.getStatus
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.beginFateOperation
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.cancelFateOperation
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.executeFateOperation
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.finishFateOperation
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.FateService.Processor.waitForFateOperation
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getActiveTservers
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getDelegationToken
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.getManagerStats
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.initiateFlush
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyNamespaceProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifySystemProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.modifyTableProperties
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeNamespaceProperty
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeSystemProperty
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.removeTableProperty
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportSplitExtent
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.reportTabletStatus
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setManagerGoalState
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setNamespaceProperty
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setSystemProperty
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setTableProperty
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdown
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdownTabletServer
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForBalance
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForFlush
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.chop
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.flushTablet
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.loadTablet
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.splitTablet
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.unloadTablet
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.applyUpdates
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.closeConditionalUpdate
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.closeUpdate
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.conditionalUpdate
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.invalidateConditionalUpdate
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.loadFiles
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startConditionalUpdate
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startUpdate
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.update
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.closeMultiScan
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.closeScan
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.continueMultiScan
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.continueScan
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.getActiveScans
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startMultiScan
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startScan
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compact
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compactionJobFailed
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.compactionJobFinished
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.contiuneGetSummaries
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.fastHalt
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.flush
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveCompactions
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getActiveLogs
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getCompactionQueueInfo
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getHistoricalStats
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletServerStatus
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.getTabletStats
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.halt
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.removeLogs
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.reserveCompactionJob
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummaries
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesForPartition
 
rethrowUnhandledExceptions() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesFromFiles
 
retriesCompleted() - Method in class org.apache.accumulo.core.util.Retry
 
retrieve() - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
 
Retry - Class in org.apache.accumulo.core.util
Encapsulates the retrying implementation for some operation.
RETRY_FACTORY - Static variable in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
Retry.BuilderDone - Interface in org.apache.accumulo.core.util
 
Retry.NeedsBackOffFactor - Interface in org.apache.accumulo.core.util
 
Retry.NeedsLogInterval - Interface in org.apache.accumulo.core.util
 
Retry.NeedsMaxWait - Interface in org.apache.accumulo.core.util
 
Retry.NeedsRetries - Interface in org.apache.accumulo.core.util
 
Retry.NeedsRetryDelay - Interface in org.apache.accumulo.core.util
 
Retry.NeedsTimeIncrement - Interface in org.apache.accumulo.core.util
 
Retry.RetryFactory - Interface in org.apache.accumulo.core.util
 
retryAfter(long, TimeUnit) - Method in interface org.apache.accumulo.core.util.Retry.NeedsRetryDelay
 
retryLoop(ZooReader.ZKFunction<R>) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
This method executes the provided function, retrying several times for transient issues.
retryLoop(ZooReader.ZKFunction<R>, Predicate<KeeperException>) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
This method executes the provided function, retrying several times for transient issues, and retrying indefinitely for special cases.
retryLoopMutator(ZooReader.ZKFunctionMutator<R>, Predicate<KeeperException>) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
This method is a special case of ZooReader.retryLoop(ZKFunction, Predicate), intended to handle ZooReaderWriter.mutateExisting(String, ZooReaderWriter.Mutator)'s additional thrown exception type.
retryTimeout - Variable in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
RETURN_VALUE - org.apache.accumulo.core.fate.Fate.TxInfo
 
returnClient(TServiceClient, ClientContext) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Return the transport used by the client to the shared pool.
returnCompressor(Compressor) - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
 
returnDecompressor(Decompressor) - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm
Returns the specified Decompressor to the codec cache if it is not null.
returnTransport(TTransport) - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportPool
 
ReverseLexicoder<T> - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder that flips the sort order from another lexicoder.
ReverseLexicoder(Lexicoder<T>) - Constructor for class org.apache.accumulo.core.client.lexicoder.ReverseLexicoder
 
revokeNamespacePermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
revokeNamespacePermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeNamespacePermission
 
revokeNamespacePermission(String, String, NamespacePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Revoke a namespace permission for a specific user on a specific namespace
revokeNamespacePermission(String, String, NamespacePermission) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
revokeNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
revokeNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
revokeNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
revokeNamespacePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
revokeNamespacePermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
revokeNamespacePermission_args(ClientService.revokeNamespacePermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
Performs a deep copy on other.
revokeNamespacePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
revokeNamespacePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
 
revokeNamespacePermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
revokeNamespacePermission_result(ClientService.revokeNamespacePermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
Performs a deep copy on other.
revokeNamespacePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
revokeSystemPermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
revokeSystemPermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeSystemPermission
 
revokeSystemPermission(String, SystemPermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Revoke a system permission from a user
revokeSystemPermission(String, SystemPermission) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
revokeSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
revokeSystemPermission(TInfo, TCredentials, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
revokeSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
revokeSystemPermission(TInfo, TCredentials, String, byte, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
revokeSystemPermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
revokeSystemPermission_args(ClientService.revokeSystemPermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
Performs a deep copy on other.
revokeSystemPermission_args(TInfo, TCredentials, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
revokeSystemPermission_call(TInfo, TCredentials, String, byte, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
 
revokeSystemPermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
revokeSystemPermission_result(ClientService.revokeSystemPermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
Performs a deep copy on other.
revokeSystemPermission_result(ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
revokeTablePermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
revokeTablePermission() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.Processor.revokeTablePermission
 
revokeTablePermission(String, String, TablePermission) - Method in interface org.apache.accumulo.core.client.admin.SecurityOperations
Revoke a table permission for a specific user on a specific table
revokeTablePermission(String, String, TablePermission) - Method in class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
revokeTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
revokeTablePermission(TInfo, TCredentials, String, String, byte) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.Iface
 
revokeTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient
 
revokeTablePermission(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncIface
 
revokeTablePermission_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
revokeTablePermission_args(ClientService.revokeTablePermission_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
Performs a deep copy on other.
revokeTablePermission_args(TInfo, TCredentials, String, String, byte) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
revokeTablePermission_call(TInfo, TCredentials, String, String, byte, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeTablePermission_call
 
revokeTablePermission_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
revokeTablePermission_result(ClientService.revokeTablePermission_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
Performs a deep copy on other.
revokeTablePermission_result(ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
RFile - Class in org.apache.accumulo.core.client.rfile
RFile is Accumulo's internal storage format for Key Value pairs.
RFile - Class in org.apache.accumulo.core.file.rfile
 
RFile() - Constructor for class org.apache.accumulo.core.client.rfile.RFile
 
RFile.InputArguments - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a larger builder pattern.
RFile.OutputArguments - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a larger builder pattern.
RFile.Reader - Class in org.apache.accumulo.core.file.rfile
 
RFile.ScannerFSOptions - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a larger builder pattern.
RFile.ScannerOptions - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a larger builder pattern.
RFile.SummaryFSOptions - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a larger builder pattern.
RFile.SummaryInputArguments - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a larger builder pattern.
RFile.SummaryOptions - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a large builder pattern.
RFile.Writer - Class in org.apache.accumulo.core.file.rfile
 
RFile.WriterFSOptions - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a larger builder pattern.
RFile.WriterOptions - Interface in org.apache.accumulo.core.client.rfile
This is an intermediate interface in a larger builder pattern.
RFileCipherOutputStream - Class in org.apache.accumulo.core.crypto.streams
This class extends CipherOutputStream to include a way to track the number of bytes that have been encrypted by the stream.
RFileCipherOutputStream(OutputStream, Cipher) - Constructor for class org.apache.accumulo.core.crypto.streams.RFileCipherOutputStream
Constructs a RFileCipherOutputStream
RFileOperations - Class in org.apache.accumulo.core.file.rfile
 
RFileOperations() - Constructor for class org.apache.accumulo.core.file.rfile.RFileOperations
 
RFileSource - Class in org.apache.accumulo.core.client.rfile
RFile metadata is stored at the end of the file.
RFileSource(InputStream, long) - Constructor for class org.apache.accumulo.core.client.rfile.RFileSource
 
RFileWriter - Class in org.apache.accumulo.core.client.rfile
This class provides an API for writing RFiles.
ROOT - org.apache.accumulo.core.clientImpl.TabletType
 
ROOT - org.apache.accumulo.core.metadata.schema.Ample.DataLevel
 
ROOT_TABLET_DIR_NAME - Static variable in class org.apache.accumulo.core.metadata.RootTable
DFS location relative to the Accumulo directory
RootTable - Class in org.apache.accumulo.core.metadata
 
RootTable() - Constructor for class org.apache.accumulo.core.metadata.RootTable
 
RootTabletLocator - Class in org.apache.accumulo.core.clientImpl
 
RootTabletMetadata - Class in org.apache.accumulo.core.metadata.schema
This class is used to serialize and deserialize root tablet metadata using GSon.
RootTabletMetadata() - Constructor for class org.apache.accumulo.core.metadata.schema.RootTabletMetadata
 
RootTabletMetadata(String) - Constructor for class org.apache.accumulo.core.metadata.schema.RootTabletMetadata
 
row - Variable in class org.apache.accumulo.core.data.Key
 
row - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
row - Variable in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
row(byte[]) - Method in interface org.apache.accumulo.core.data.KeyBuilder.RowStep
Set the row of the Key that this builder will build to the parameter.
row(byte[], int, int) - Method in interface org.apache.accumulo.core.data.KeyBuilder.RowStep
Set the row of the Key that this builder will build to the parameter.
row(CharSequence) - Method in interface org.apache.accumulo.core.data.KeyBuilder.RowStep
Set the row of the Key that this builder will build to the parameter.
row(Text) - Method in interface org.apache.accumulo.core.data.KeyBuilder.RowStep
Set the row of the Key that this builder will build to the parameter.
ROW - org.apache.accumulo.core.data.PartialKey
 
ROW - org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
ROW - org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
ROW_COLFAM - org.apache.accumulo.core.data.PartialKey
 
ROW_COLFAM_COLQUAL - org.apache.accumulo.core.data.PartialKey
 
ROW_COLFAM_COLQUAL_COLVIS - org.apache.accumulo.core.data.PartialKey
 
ROW_COLFAM_COLQUAL_COLVIS_TIME - org.apache.accumulo.core.data.PartialKey
 
ROW_COLFAM_COLQUAL_COLVIS_TIME_DEL - org.apache.accumulo.core.data.PartialKey
 
ROW_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
RowColumnSampler - Class in org.apache.accumulo.core.client.sample
This sampler can hash any subset of a Key's fields.
RowColumnSampler() - Constructor for class org.apache.accumulo.core.client.sample.RowColumnSampler
 
rowDecoder(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
Given a value generated by the rowEncoder implementation, recreate the original Key, Value pairs.
rowDecoder(Key, Value) - Method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
RowDeletingIterator - Class in org.apache.accumulo.core.iterators.user
An iterator for deleting whole rows.
RowDeletingIterator() - Constructor for class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
rowEncoder(List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
Take a stream of keys and values.
rowEncoder(List<Key>, List<Value>) - Method in class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
RowEncodingIterator - Class in org.apache.accumulo.core.iterators.user
The RowEncodingIterator is designed to provide row-isolation so that queries see mutations as atomic.
RowEncodingIterator() - Constructor for class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
RowFilter - Class in org.apache.accumulo.core.iterators.user
This iterator makes it easy to select rows that meet a given criteria.
RowFilter() - Constructor for class org.apache.accumulo.core.iterators.user.RowFilter
 
RowFunctor - Class in org.apache.accumulo.core.file.keyfunctor
 
RowFunctor() - Constructor for class org.apache.accumulo.core.file.keyfunctor.RowFunctor
 
RowIterator - Class in org.apache.accumulo.core.client
Group Key/Value pairs into Iterators over rows.
RowIterator(Iterable<Map.Entry<Key, Value>>) - Constructor for class org.apache.accumulo.core.client.RowIterator
Create an iterator from an Iterable.
RowIterator(Iterator<Map.Entry<Key, Value>>) - Constructor for class org.apache.accumulo.core.client.RowIterator
Create an iterator from an (ordered) sequence of KeyValue pairs.
RowRange(KeyExtent) - Constructor for class org.apache.accumulo.core.summary.Gatherer.RowRange
 
RowRange(TRowRange) - Constructor for class org.apache.accumulo.core.summary.Gatherer.RowRange
 
RowRange(Text, Text) - Constructor for class org.apache.accumulo.core.summary.Gatherer.RowRange
 
RowSampler - Class in org.apache.accumulo.core.client.sample
Builds a sample based on entire rows.
RowSampler() - Constructor for class org.apache.accumulo.core.client.sample.RowSampler
 
RPC_PREFIX - org.apache.accumulo.core.conf.Property
 
RPC_SASL_QOP - org.apache.accumulo.core.conf.Property
 
RPC_SSL_CIPHER_SUITES - org.apache.accumulo.core.conf.Property
 
RPC_SSL_CLIENT_PROTOCOL - org.apache.accumulo.core.conf.Property
 
RPC_SSL_ENABLED_PROTOCOLS - org.apache.accumulo.core.conf.Property
 
RPC_SSL_KEYSTORE_PASSWORD - org.apache.accumulo.core.conf.Property
 
RPC_SSL_KEYSTORE_PATH - org.apache.accumulo.core.conf.Property
 
RPC_SSL_KEYSTORE_TYPE - org.apache.accumulo.core.conf.Property
 
RPC_SSL_TRUSTSTORE_PASSWORD - org.apache.accumulo.core.conf.Property
 
RPC_SSL_TRUSTSTORE_PATH - org.apache.accumulo.core.conf.Property
 
RPC_SSL_TRUSTSTORE_TYPE - org.apache.accumulo.core.conf.Property
 
RPC_TRANSPORT_IDLE_TIMEOUT - org.apache.accumulo.core.conf.ClientProperty
 
RPC_USE_JSSE - org.apache.accumulo.core.conf.Property
 
rpcCreds() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Serialize the credentials just before initiating the RPC call
running - Variable in class org.apache.accumulo.core.manager.thrift.Compacting
 
RUNNING - org.apache.accumulo.core.client.admin.ScanState
 
RUNNING - org.apache.accumulo.core.manager.thrift.Compacting._Fields
 
RUNNING - org.apache.accumulo.core.tabletscan.thrift.ScanState
 
RunningCompaction - Class in org.apache.accumulo.core.util.compaction
 
RunningCompaction(TExternalCompaction) - Constructor for class org.apache.accumulo.core.util.compaction.RunningCompaction
 
RunningCompaction(TExternalCompactionJob, String, String) - Constructor for class org.apache.accumulo.core.util.compaction.RunningCompaction
 
RunningCompactionInfo - Class in org.apache.accumulo.core.util.compaction
 
RunningCompactionInfo(TExternalCompaction) - Constructor for class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
Info parsed about the external running compaction.
runtime - Variable in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
RUNTIME - org.apache.accumulo.core.manager.thrift.RecoveryStatus._Fields
 

S

SAFE_MODE - org.apache.accumulo.core.manager.thrift.ManagerGoalState
 
SAFE_MODE - org.apache.accumulo.core.manager.thrift.ManagerState
 
safeAdd(long, long) - Static method in class org.apache.accumulo.core.iterators.LongCombiner
 
sameNamespaceAs(String) - Static method in class org.apache.accumulo.core.util.Validators
 
SampleIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
 
SampleIterator(SortedKeyValueIterator<Key, Value>, Sampler) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.SampleIterator
 
SampleNotPresentException - Exception in org.apache.accumulo.core.client
Exception thrown when a table does not have sampling configured or when sampling is configured but it differs from what was requested.
SampleNotPresentException() - Constructor for exception org.apache.accumulo.core.client.SampleNotPresentException
 
SampleNotPresentException(String) - Constructor for exception org.apache.accumulo.core.client.SampleNotPresentException
 
SampleNotPresentException(String, Exception) - Constructor for exception org.apache.accumulo.core.client.SampleNotPresentException
 
Sampler - Interface in org.apache.accumulo.core.client.sample
A function that decides which key values are stored in a tables sample.
SAMPLER_CONFIG - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
 
SAMPLER_CONFIG - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
samplerConfig - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
samplerConfig - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
SamplerConfiguration - Class in org.apache.accumulo.core.client.sample
This class encapsulates configuration and options needed to setup and use sampling.
SamplerConfiguration(Class<? extends Sampler>) - Constructor for class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
SamplerConfiguration(String) - Constructor for class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
SamplerConfigurationImpl - Class in org.apache.accumulo.core.sample.impl
 
SamplerConfigurationImpl() - Constructor for class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
SamplerConfigurationImpl(DataInput) - Constructor for class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
SamplerConfigurationImpl(String, Map<String, String>) - Constructor for class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
SamplerConfigurationImpl(SamplerConfiguration) - Constructor for class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
SamplerFactory - Class in org.apache.accumulo.core.sample.impl
 
SamplerFactory() - Constructor for class org.apache.accumulo.core.sample.impl.SamplerFactory
 
SASL_ENABLED - org.apache.accumulo.core.conf.ClientProperty
 
SASL_KERBEROS_SERVER_PRIMARY - org.apache.accumulo.core.conf.ClientProperty
 
SASL_QOP - org.apache.accumulo.core.conf.ClientProperty
 
SaslClientDigestCallbackHandler - Class in org.apache.accumulo.core.rpc
Client-side callbackhandler for sasl authentication which is the client-side sibling to the server-side SaslDigestCallbackHandler.
SaslClientDigestCallbackHandler(String, char[]) - Constructor for class org.apache.accumulo.core.rpc.SaslClientDigestCallbackHandler
 
SaslClientDigestCallbackHandler(DelegationTokenImpl) - Constructor for class org.apache.accumulo.core.rpc.SaslClientDigestCallbackHandler
 
SaslConnectionParams - Class in org.apache.accumulo.core.rpc
Connection parameters for setting up a TSaslTransportFactory
SaslConnectionParams(Properties, AuthenticationToken) - Constructor for class org.apache.accumulo.core.rpc.SaslConnectionParams
 
SaslConnectionParams(AccumuloConfiguration, AuthenticationToken) - Constructor for class org.apache.accumulo.core.rpc.SaslConnectionParams
 
SaslConnectionParams.QualityOfProtection - Enum in org.apache.accumulo.core.rpc
Enumeration around Sasl.QOP
SaslConnectionParams.SaslMechanism - Enum in org.apache.accumulo.core.rpc
The SASL mechanism to use for authentication
SaslDigestCallbackHandler - Class in org.apache.accumulo.core.rpc
Common serialization methods across the client and server callback handlers for SASL.
SaslDigestCallbackHandler() - Constructor for class org.apache.accumulo.core.rpc.SaslDigestCallbackHandler
 
saslEnabled() - Method in interface org.apache.accumulo.core.clientImpl.ClientInfo
 
saslEnabled() - Method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
saslProperties - Variable in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
saveKeyValues() - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
saveKeyValues() - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.Options
Saves the key values seen in the metadata table for each tablet.
sawOldPrevEndRow() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
sawPrevEndRow() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
scale(TimeUnit) - Method in class org.apache.accumulo.core.util.OpTimer
Returns the current elapsed time scaled to the provided time unit.
scan - org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
 
scan(ClientContext, ThriftScanner.ScanState, long) - Static method in class org.apache.accumulo.core.clientImpl.ThriftScanner
 
SCAN_BATCH_SIZE - Static variable in class org.apache.accumulo.core.Constants
 
SCAN_ID - org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
 
SCAN_ID - org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
 
SCAN_ID - org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
SCAN_ID - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args._Fields
 
SCAN_ID - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args._Fields
 
SCAN_ID - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args._Fields
 
SCAN_ID - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args._Fields
 
SCAN_RATE - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
SCAN_SERVER_SELECTOR - org.apache.accumulo.core.conf.ClientProperty
 
SCAN_SERVER_SELECTOR_OPTS_PREFIX - org.apache.accumulo.core.conf.ClientProperty
 
ScanCacheProvider - Class in org.apache.accumulo.core.file.blockfile.impl
 
ScanCacheProvider(AccumuloConfiguration, ScanDispatch, BlockCache, BlockCache) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.ScanCacheProvider
 
ScanDispatch - Interface in org.apache.accumulo.core.spi.scan
Encapsulates information about how a scan should be executed.
ScanDispatch.Builder - Interface in org.apache.accumulo.core.spi.scan
 
ScanDispatch.CacheUsage - Enum in org.apache.accumulo.core.spi.scan
Communicates how a scan should use cache.
ScanDispatcher - Interface in org.apache.accumulo.core.spi.scan
A per table scan dispatcher that decides which executor should be used to process a scan.
ScanDispatcher.DispatchParameters - Interface in org.apache.accumulo.core.spi.scan
ScanDispatcher.InitParameters - Interface in org.apache.accumulo.core.spi.scan
The method parameters for ScanDispatcher.init(InitParameters).
ScanExecutor - Interface in org.apache.accumulo.core.spi.scan
Interface for obtaining information about a scan executor
ScanExecutor.Config - Interface in org.apache.accumulo.core.spi.scan
 
ScanExecutorConfig(String, int, OptionalInt, Optional<String>, Map<String, String>, boolean) - Constructor for class org.apache.accumulo.core.conf.AccumuloConfiguration.ScanExecutorConfig
 
ScanFileColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ScanFileColumnFamily
 
scanId - Variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
scanID - Variable in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
scanID - Variable in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
scanID - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
scanID - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
scanID - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
scanID - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
ScanInfo - Interface in org.apache.accumulo.core.spi.scan
Provides information about an active Accumulo scan against a tablet.
ScanInfo.Type - Enum in org.apache.accumulo.core.spi.scan
 
scanMetadataTable() - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableOptions
Obtain tablet metadata by scanning the metadata table.
Scanner - Interface in org.apache.accumulo.core.client
Scans a table over a given range.
SCANNER_BATCH_SIZE - org.apache.accumulo.core.conf.ClientProperty
 
SCANNER_DEFAULT_READAHEAD_THRESHOLD - Static variable in class org.apache.accumulo.core.Constants
 
ScannerBase - Interface in org.apache.accumulo.core.client
This class hosts configuration methods that are shared between different types of scanners.
ScannerBase.ConsistencyLevel - Enum in org.apache.accumulo.core.client
Consistency level for the scanner.
scannerBatchSize(int) - Method in interface org.apache.accumulo.core.client.AccumuloClient.ConnectionOptions
Build with default batch size for Scanner
scannerBatchSize(int) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
ScannerImpl - Class in org.apache.accumulo.core.clientImpl
provides scanner functionality "Clients can iterate over multiple column families, and there are several mechanisms for limiting the rows, columns, and timestamps traversed by a scan.
ScannerImpl(ClientContext, TableId, Authorizations) - Constructor for class org.apache.accumulo.core.clientImpl.ScannerImpl
 
ScannerIterator - Class in org.apache.accumulo.core.clientImpl
 
ScannerOptions - Class in org.apache.accumulo.core.clientImpl
 
ScannerOptions() - Constructor for class org.apache.accumulo.core.clientImpl.ScannerOptions
 
ScannerOptions(ScannerOptions) - Constructor for class org.apache.accumulo.core.clientImpl.ScannerOptions
 
scanning - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
ScanPrioritizer - Interface in org.apache.accumulo.core.spi.scan
A factory for creating comparators used for prioritizing scans.
ScanPrioritizer.CreateParameters - Interface in org.apache.accumulo.core.spi.scan
scanRate - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
ScanReaderBuilder() - Constructor for class org.apache.accumulo.core.file.FileOperations.ScanReaderBuilder
 
ScanResult - Class in org.apache.accumulo.core.dataImpl.thrift
 
ScanResult() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
ScanResult(List<TKeyValue>, boolean) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
ScanResult(ScanResult) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.ScanResult
Performs a deep copy on other.
ScanResult._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
scans - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
SCANS - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
SCANS - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
ScanServerAttempt - Interface in org.apache.accumulo.core.spi.scan
This object is used to communicate what previous actions were attempted, when they were attempted, and the result of those attempts
ScanServerAttempt.Result - Enum in org.apache.accumulo.core.spi.scan
 
ScanServerAttemptsImpl - Class in org.apache.accumulo.core.clientImpl
This class is used to track scan attempts for the ScanServerSelector.
ScanServerAttemptsImpl() - Constructor for class org.apache.accumulo.core.clientImpl.ScanServerAttemptsImpl
 
ScanServerBusyException - Exception in org.apache.accumulo.core.tabletscan.thrift
 
ScanServerBusyException() - Constructor for exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
ScanServerBusyException(ScanServerBusyException) - Constructor for exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
Performs a deep copy on other.
ScanServerBusyException._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ScanServerFileReferenceSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.ScanServerFileReferenceSection
 
ScanServerInfo - Interface in org.apache.accumulo.core.spi.scan
Information about a scan server.
ScanServerRefTabletFile - Class in org.apache.accumulo.core.metadata
 
ScanServerRefTabletFile(String, String, UUID) - Constructor for class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
ScanServerRefTabletFile(String, Text, Text) - Constructor for class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
ScanServerSelections - Interface in org.apache.accumulo.core.spi.scan
Returned by ScanServerSelector.selectServers(ScanServerSelector.SelectorParameters) to specify what scan servers to use and how to use them.
ScanServerSelector - Interface in org.apache.accumulo.core.spi.scan
A client side plugin that determines what scan servers to use for eventually consistent scans.
ScanServerSelector.InitParameters - Interface in org.apache.accumulo.core.spi.scan
This interface exists so that is easier to evolve what is passed to ScanServerSelector.init(InitParameters) without having to make breaking changes.
ScanServerSelector.SelectorParameters - Interface in org.apache.accumulo.core.spi.scan
This interface exists so that is easier to evolve what is passed to ScanServerSelector.selectServers(SelectorParameters) without having to make breaking changes.
ScanState - Enum in org.apache.accumulo.core.client.admin
 
ScanState - Enum in org.apache.accumulo.core.tabletscan.thrift
 
ScanState(ClientContext, TableId, Authorizations, Range, SortedSet<Column>, int, List<IterInfo>, Map<String, Map<String, String>>, boolean, long, SamplerConfiguration, long, String, Map<String, String>, boolean) - Constructor for class org.apache.accumulo.core.clientImpl.ThriftScanner.ScanState
 
scanTable(String) - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata.Builder
 
scanTable(String) - Method in interface org.apache.accumulo.core.metadata.schema.TabletsMetadata.TableOptions
Obtain tablet metadata by scanning an arbitrary table.
ScanTimedOutException() - Constructor for exception org.apache.accumulo.core.clientImpl.ThriftScanner.ScanTimedOutException
 
ScanType - Enum in org.apache.accumulo.core.client.admin
 
ScanType - Enum in org.apache.accumulo.core.tabletscan.thrift
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
sec - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
sec - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
sec - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
sec - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
sec - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
sec - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
sec - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
sec - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
sec - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
sec - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
sec - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
sec - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
sec - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
sec - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result._Fields
 
SEC - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
 
SEC - org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
 
SEC - org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result._Fields
 
SEC - org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result._Fields
 
SEC - org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
 
SEC - org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
 
SEC - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result._Fields
 
SEC - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result._Fields
 
SEC - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result._Fields
 
SEC - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result._Fields
 
SEC - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result._Fields
 
SEC - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result._Fields
 
SEC - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result._Fields
 
SEC - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result._Fields
 
secret - Variable in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
SECRET - org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
 
Section - Class in org.apache.accumulo.core.schema
 
Section(String, boolean, String, boolean) - Constructor for class org.apache.accumulo.core.schema.Section
 
SecurityErrorCode - Enum in org.apache.accumulo.core.client.security
 
SecurityErrorCode - Enum in org.apache.accumulo.core.clientImpl.thrift
 
securityOperations() - Method in interface org.apache.accumulo.core.client.AccumuloClient
Retrieves a SecurityOperations object to perform user security operations, such as creating users.
securityOperations() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
SecurityOperations - Interface in org.apache.accumulo.core.client.admin
Provides a class for managing users and permissions
SecurityOperationsImpl - Class in org.apache.accumulo.core.clientImpl
 
SecurityOperationsImpl(ClientContext) - Constructor for class org.apache.accumulo.core.clientImpl.SecurityOperationsImpl
 
seedTransaction(String, long, Repo<T>, boolean, String) - Method in class org.apache.accumulo.core.fate.Fate
 
seek(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.CachedBlockRead
 
seek(int) - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
seek(long) - Method in class org.apache.accumulo.core.file.streams.RateLimitedInputStream
 
seek(long) - Method in class org.apache.accumulo.core.file.streams.SeekableDataInputStream
 
seek(Range) - Method in class org.apache.accumulo.core.iterators.OrIterator.TermSource
Converts the given Range into the correct Range for this TermSource (per this expected table structure) and then seeks this TermSource's SKVI.
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.ColumnFamilyCounter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.Combiner
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.DevNull
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.Filter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.ServerFilter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.ServerSkippingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.SkippingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in interface org.apache.accumulo.core.iterators.SortedKeyValueIterator
Seeks to the first key in the Range, restricting the resulting K,V pairs to those with the specified columns.
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.RowDeletingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.RowFilter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.MultiIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.StatsIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
seek(Range, Collection<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
seek(FileSKVIterator, Range, String, Map<String, ArrayList<ByteSequence>>) - Static method in class org.apache.accumulo.core.util.LocalityGroupUtil
This method created to help seek an rfile for a locality group obtained from RFile.Reader.getLocalityGroupCF().
seek(HeapIterator, LocalityGroupIterator.LocalityGroupContext, Range, Collection<ByteSequence>, boolean, LocalityGroupIterator.LocalityGroupSeekCache) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator
This seek method will reuse the supplied LocalityGroupSeekCache if it can.
SeekableByteArrayInputStream - Class in org.apache.accumulo.core.file.blockfile.impl
This class is like byte array input stream with two differences.
SeekableByteArrayInputStream(byte[]) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
SeekableByteArrayInputStream(byte[], int) - Constructor for class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
SeekableDataInputStream - Class in org.apache.accumulo.core.file.streams
A wrapper converting a Seekable InputStream into a Seekable DataInputStream
SeekableDataInputStream(StreamType) - Constructor for class org.apache.accumulo.core.file.streams.SeekableDataInputStream
 
seekBlock(Key, CachableBlockFile.CachedBlockRead) - Method in class org.apache.accumulo.core.file.rfile.BlockIndex
 
seekColfams - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
seekColumnFamilies - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
seekColumnFamiliesInclusive - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
SeekingFilter - Class in org.apache.accumulo.core.iterators.user
Base class for filters that can skip over key-value pairs which do not match their filter predicate.
SeekingFilter() - Constructor for class org.apache.accumulo.core.iterators.user.SeekingFilter
 
SeekingFilter.AdvanceResult - Enum in org.apache.accumulo.core.iterators.user
 
SeekingFilter.FilterResult - Class in org.apache.accumulo.core.iterators.user
 
seekRange - Variable in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
seekToBeginning - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
seekToBeginning() - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
Seek the constructed iterator to the beginning of its domain before returning.
seekToBeginning(boolean) - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
If true, seek the constructed iterator to the beginning of its domain before returning.
seekToNewSource(long) - Method in class org.apache.accumulo.core.file.streams.RateLimitedInputStream
 
seekToNewSource(long) - Method in class org.apache.accumulo.core.file.streams.SeekableDataInputStream
 
SEEN_STAT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
This tracks the total number of key/values seen by the Summarizer.Collector
select(CompactionSelector.SelectionParameters) - Method in interface org.apache.accumulo.core.client.admin.compaction.CompactionSelector
 
select(CompactionSelector.SelectionParameters) - Method in class org.apache.accumulo.core.client.admin.compaction.TooManyDeletesSelector
 
select(CompactionSelector.SelectionParameters) - Method in class org.apache.accumulo.core.compaction.ShellCompactCommandSelector
 
selected(KeyExtent, CompactionKind, Collection<StoredTabletFile>) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
selectedAll() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
Selection(Collection<CompactableFile>) - Constructor for class org.apache.accumulo.core.client.admin.compaction.CompactionSelector.Selection
 
SELECTOR - org.apache.accumulo.core.spi.compaction.CompactionKind
Set of files selected by a CompactionSelector configured for a table.
SELECTOR - org.apache.accumulo.core.tabletserver.thrift.TCompactionKind
 
selectServers(ScanServerSelector.SelectorParameters) - Method in class org.apache.accumulo.core.spi.scan.ConfigurableScanServerSelector
 
selectServers(ScanServerSelector.SelectorParameters) - Method in interface org.apache.accumulo.core.spi.scan.ScanServerSelector
Uses the ScanServerSelector.SelectorParameters to determine which, if any, ScanServer should be used for scanning a tablet.
selectSummaries(Predicate<SummarizerConfiguration>) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryOptions
This method allows retrieving a subset of summary data from a file.
send_applyUpdates(TInfo, long, TKeyExtent, List<TMutation>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_authenticate(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_authenticateUser(TInfo, TCredentials, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_beginFateOperation(TInfo, TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
send_cancel(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
send_cancel(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
send_cancelFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
send_changeAuthorizations(TInfo, TCredentials, String, List<ByteBuffer>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_changeLocalUserPassword(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_checkClass(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_checkNamespaceClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_checkTableClass(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_chop(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
send_closeConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_closeMultiScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
send_closeScan(TInfo, long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
send_closeUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_compact(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_compactionCompleted(TInfo, TCredentials, String, TKeyExtent, TCompactionStats) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
send_compactionFailed(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
send_compactionJobFailed(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_compactionJobFinished(TInfo, TCredentials, String, TKeyExtent, long, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_conditionalUpdate(TInfo, long, Map<TKeyExtent, List<TConditionalMutation>>, List<String>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_continueMultiScan(TInfo, long, long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
send_continueScan(TInfo, long, long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
send_contiuneGetSummaries(TInfo, long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_createLocalUser(TInfo, TCredentials, String, ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_dropLocalUser(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_executeFateOperation(TInfo, TCredentials, long, FateOperation, List<ByteBuffer>, Map<String, String>, boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
send_fails() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
send_fastHalt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_finishFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
send_flush(TInfo, TCredentials, String, String, ByteBuffer, ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_flushTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
send_getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
send_getActiveCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_getActiveLogs(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_getActiveScans(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
send_getActiveTservers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_getCompactionJob(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
send_getCompactionQueueInfo(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_getCompletedCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
send_getConfiguration(TInfo, TCredentials, ConfigurationType) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getDelegationToken(TInfo, TCredentials, TDelegationTokenConfig) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_getDiskUsage(Set<String>, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getHistoricalStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_getInstanceId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getManagerStats(TInfo, TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_getNamespaceConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getNamespaceProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getRootTabletLocation() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getRunningCompaction(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
send_getRunningCompactionId(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.Client
 
send_getRunningCompactions(TInfo, TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
send_getStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.Client
 
send_getSystemProperties(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getTableConfiguration(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getTableProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getTabletServerStatus(TInfo, TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_getTabletStats(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_getUserAuthorizations(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getVersionedNamespaceProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getVersionedSystemProperties(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getVersionedTableProperties(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_getZooKeepers() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_grantNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_grantSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_grantTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_halt(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_hasNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_hasSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_hasTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_initiateFlush(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_invalidateConditionalUpdate(TInfo, long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_isActive(TInfo, long) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_listLocalUsers(TInfo, TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_loadFiles(TInfo, TCredentials, long, String, Map<TKeyExtent, Map<String, DataFileInfo>>, boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_loadTablet(TInfo, TCredentials, String, TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
send_modifyNamespaceProperties(TInfo, TCredentials, String, TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_modifySystemProperties(TInfo, TCredentials, TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_modifyTableProperties(TInfo, TCredentials, String, TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_ping(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_removeLogs(TInfo, TCredentials, List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_removeNamespaceProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_removeSystemProperty(TInfo, TCredentials, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_removeTableProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_reportSplitExtent(TInfo, TCredentials, String, TabletSplit) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_reportTabletStatus(TInfo, TCredentials, String, TabletLoadState, TKeyExtent) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_reserveCompactionJob(TInfo, TCredentials, String, long, String, String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_revokeNamespacePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_revokeSystemPermission(TInfo, TCredentials, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_revokeTablePermission(TInfo, TCredentials, String, String, byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.Client
 
send_setManagerGoalState(TInfo, TCredentials, ManagerGoalState) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_setNamespaceProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_setSystemProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_setTableProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_shutdown(TInfo, TCredentials, boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_shutdownTabletServer(TInfo, TCredentials, String, boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
send_startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String, TDurability, String) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_startGetSummaries(TInfo, TCredentials, TSummaryRequest) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_startGetSummariesForPartition(TInfo, TCredentials, TSummaryRequest, int, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_startGetSummariesFromFiles(TInfo, TCredentials, TSummaryRequest, Map<String, List<TRowRange>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
send_startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, TSamplerConfiguration, long, String, Map<String, String>, long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
send_startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, TSamplerConfiguration, long, String, Map<String, String>, long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
send_startUpdate(TInfo, TCredentials, TDurability) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_success() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
send_throwsError() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
send_unloadTablet(TInfo, TCredentials, String, TKeyExtent, TUnloadTabletGoal, long) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
send_update(TInfo, TCredentials, TKeyExtent, TMutation, TDurability) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
send_updateCompactionStatus(TInfo, TCredentials, String, TCompactionStatusUpdate, long) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
send_waitForBalance(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
send_waitForFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
send_waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
SEPARATOR - Static variable in class org.apache.accumulo.core.clientImpl.Namespace
 
SequenceFileIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
 
SequenceFileIterator(SequenceFile.Reader, boolean) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
SequenceLexicoder<E> - 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.
SequenceLexicoder(Lexicoder<E>) - Constructor for class org.apache.accumulo.core.client.lexicoder.SequenceLexicoder
Primary constructor.
SERIALIZATION_ERROR - org.apache.accumulo.core.client.security.SecurityErrorCode
 
SERIALIZATION_ERROR - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
serialize() - Method in class org.apache.accumulo.core.clientImpl.Credentials
Converts the current object to a serialized form.
serialize() - Method in class org.apache.accumulo.core.lock.ServiceLockData
 
serialize() - Method in class org.apache.accumulo.core.security.Authorizations
Returns a serialized form of these authorizations.
serialize(byte[], Type, JsonSerializationContext) - Method in class org.apache.accumulo.core.util.json.ByteArrayToBase64TypeAdapter
 
serialize(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil.LockID
 
serialize(DelegationTokenConfig) - Static method in class org.apache.accumulo.core.clientImpl.DelegationTokenConfigSerializer
Serialize the delegation token config into the thrift variant
serialize(AuthenticationToken) - Static method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.AuthenticationTokenSerializer
A convenience method to serialize tokens.
serialize(TBase<?, ?>) - Method in class org.apache.accumulo.core.util.ThriftMessageUtil
Convert the msg to a byte array representation
serializeMetadata(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Reader
 
serv - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
SERV - org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
 
server - Variable in class org.apache.accumulo.core.manager.thrift.DeadServer
 
server - Variable in class org.apache.accumulo.core.metadata.SuspendingTServer
 
server - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
SERVER - org.apache.accumulo.core.manager.thrift.DeadServer._Fields
 
SERVER - org.apache.accumulo.core.singletons.SingletonManager.Mode
In this mode singletons are never disabled, unless the CLOSED mode is entered.
SERVER_NAME - org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
 
SERVER_NAME - org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
ServerColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
ServerFilter - Class in org.apache.accumulo.core.iterators
An optimized version of Filter.
ServerFilter(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.ServerFilter
 
serverInstance(TabletMetadata.Location) - Static method in class org.apache.accumulo.core.metadata.TabletLocationState
 
serverName - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
serverName - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
SERVERS_SHUTTING_DOWN - org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
serverSideIteratorList - Variable in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
serverSideIteratorOptions - Variable in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
ServerSkippingIterator - Class in org.apache.accumulo.core.iterators
An optimized version of SkippingIterator.
ServerSkippingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.ServerSkippingIterator
 
serversShuttingDown - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
serversWaitedForWrites - Static variable in class org.apache.accumulo.core.clientImpl.ThriftScanner
 
ServerWrappingIterator - Class in org.apache.accumulo.core.iterators
An optimized version of WrappingIterator.
ServerWrappingIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
SERVICE_NAME - Static variable in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
ServiceDescriptor(UUID, ServiceLockData.ThriftService, String) - Constructor for class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptor
 
ServiceDescriptor(UUID, ServiceLockData.ThriftService, String, String) - Constructor for class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptor
 
ServiceDescriptors() - Constructor for class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptors
 
ServiceDescriptors(HashSet<ServiceLockData.ServiceDescriptor>) - Constructor for class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptors
 
ServiceEnvironment - Interface in org.apache.accumulo.core.spi.common
This interface exposes Accumulo system level information to plugins in a stable manner.
ServiceEnvironment.Configuration - Interface in org.apache.accumulo.core.spi.common
 
ServiceLock - Class in org.apache.accumulo.core.lock
 
ServiceLock(ZooKeeper, ServiceLock.ServiceLockPath, UUID) - Constructor for class org.apache.accumulo.core.lock.ServiceLock
 
ServiceLock.AccumuloLockWatcher - Interface in org.apache.accumulo.core.lock
 
ServiceLock.LockLossReason - Enum in org.apache.accumulo.core.lock
 
ServiceLock.LockWatcher - Interface in org.apache.accumulo.core.lock
 
ServiceLock.ServiceLockPath - Class in org.apache.accumulo.core.lock
 
ServiceLockData - Class in org.apache.accumulo.core.lock
 
ServiceLockData(UUID, String, ServiceLockData.ThriftService) - Constructor for class org.apache.accumulo.core.lock.ServiceLockData
 
ServiceLockData(UUID, String, ServiceLockData.ThriftService, String) - Constructor for class org.apache.accumulo.core.lock.ServiceLockData
 
ServiceLockData(ServiceLockData.ServiceDescriptors) - Constructor for class org.apache.accumulo.core.lock.ServiceLockData
 
ServiceLockData.ServiceDescriptor - Class in org.apache.accumulo.core.lock
An object that describes a process, the group assigned to that process, the Thrift service and the address to use to communicate with that service.
ServiceLockData.ServiceDescriptors - Class in org.apache.accumulo.core.lock
A set of ServiceDescriptor's
ServiceLockData.ThriftService - Enum in org.apache.accumulo.core.lock
Thrift Service list
SESS_ID - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args._Fields
 
SESS_ID - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args._Fields
 
SESS_ID - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args._Fields
 
sessID - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
sessID - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
sessID - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
SESSION_EXPIRED - org.apache.accumulo.core.lock.ServiceLock.LockLossReason
 
SESSION_ID - org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
 
SESSION_ID - org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
SESSION_ID - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args._Fields
 
sessionId - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
sessionId - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
sessionId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
set(byte[]) - Method in class org.apache.accumulo.core.data.Value
Sets the byte data of this value.
set(int, T) - Method in class org.apache.accumulo.core.util.PreAllocatedArray
Set the element at the specified index, and return the old value.
set(String, String) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
Sets a property in this configuration.
set(Property, String) - Method in class org.apache.accumulo.core.conf.ConfigurationCopy
Sets a property in this configuration.
set(Key) - Method in class org.apache.accumulo.core.data.Key
Sets this key's row, column family, column qualifier, column visibility, timestamp, and delete marker to be the same as another key's.
set(MultiLevelIndex.IndexEntry) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader.IndexIterator
 
SET_PROPERTY - org.apache.accumulo.core.clientImpl.thrift.TableOperation
 
SET_TIME - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args._Fields
 
setAge(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setAge(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setAgeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setAgeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setArguments(List<ByteBuffer>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setArgumentsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setArray(byte[], int, int) - Method in class org.apache.accumulo.core.util.MutableByteSequence
 
setAuthenticationToken(Properties, AuthenticationToken) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
setAuthorizationFailures(Map<TKeyExtent, SecurityErrorCode>) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
setAuthorizationFailuresIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setAuthorizations(List<ByteBuffer>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setAuthorizations(IteratorSetting, Authorizations) - Static method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Configure authorizations used for post transformation filtering.
setAuthorizations(IteratorSetting, Authorizations) - Static method in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
setAuthorizations(Authorizations) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
A set of authorization labels that will be checked against the column visibility of each key in order to filter data.
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setAuthorizationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setAutoClean(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setAutoCleanIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setBackOffFactor(double) - Method in class org.apache.accumulo.core.util.Retry
 
setBadTServers(Map<String, Byte>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setBadTServersIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setBatch(Map<TKeyExtent, List<TRange>>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setBatchIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setBatchSize(int) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
setBatchSize(int) - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
setBatchSize(int) - Method in interface org.apache.accumulo.core.client.Scanner
Sets the number of Key/Value pairs that will be fetched at a time from a tablet server.
setBatchSize(int) - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
setBatchSize(int) - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
setBatchSize(int) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setBatchSizeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setBatchTimeout(long, TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
This setting determines how long a scanner will wait to fill the returned batch.
setBatchTimeout(long, TimeUnit) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
setBatchTimeOut(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setBatchTimeOut(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setBatchTimeOutIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setBatchTimeOutIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setBounds(TRowRange) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setBoundsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setBulkImports(List<BulkImportStatus>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setBulkImports(List<BulkImportStatus>) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setBulkImportsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setBulkImportsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setBulks(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setBulksIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setBusyTimeout(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
setBusyTimeout(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
setBusyTimeout(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setBusyTimeout(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setBusyTimeoutIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
setBusyTimeoutIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
setBusyTimeoutIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setBusyTimeoutIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setBytes(Properties, Long) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
setCacheProvider(CacheProvider) - Method in class org.apache.accumulo.core.file.blockfile.impl.CachableBlockFile.Reader
 
setCacheProvider(CacheProvider) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
setCacheProvider(CacheProvider) - Method in interface org.apache.accumulo.core.file.FileSKVIterator
 
setCacheProvider(CacheProvider) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
setCacheProvider(CacheProvider) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
setCandidates(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setCandidatesIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setCf(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setCf(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setCfg(TDelegationTokenConfig) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
setCfgIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
setCfIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setClassLoaderContext(String) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Sets the name of the classloader context on this scanner.
setClassLoaderContext(String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Sets the name of the classloader context on this scanner.
setClassLoaderContext(String) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
setClassLoaderContext(String) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setClassLoaderContext(String) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setClassLoaderContext(String) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setClassLoaderContext(String) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setClassLoaderContextIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setClassLoaderContextIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setClassLoaderContextIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setClassLoaderContextIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setClassname(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
setClassName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setClassName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setClassName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setClassName(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
setClassName(String) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
setClassnameIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
setClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
setClient(String) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setClientAuth(boolean) - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
setClientIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setCmid(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
setCmidIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
setCode(SecurityErrorCode) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
setCodeIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
setColFamily(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setColFamily(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setColFamilyIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setColfs(IteratorSetting, String, String) - Static method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
A convenience method for setting the index column family and document column family prefix.
setColQualifier(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setColQualifier(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setColQualifierIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setColumnFamilies(IteratorSetting, Text[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
Encode the columns to be used when iterating.
setColumnFamilies(IteratorSetting, Text[], boolean[]) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
Encode columns and NOT flags indicating which columns should be negated (docIDs will be excluded if matching negated columns, instead of included).
setColumnFamily(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColumnFamily(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColumnFamilyIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColumnQualifier(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColumnQualifier(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColumnQualifierIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColumns(List<TColumn>) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setColumns(List<TColumn>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setColumns(List<TColumn>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setColumns(IteratorSetting, List<IteratorSetting.Column>) - Static method in class org.apache.accumulo.core.iterators.Combiner
A convenience method to set which columns a combiner should be applied to.
setColumnsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setColumnsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setColumnsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setColumnVisibility(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColumnVisibility(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColumnVisibilityIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setColVisibility(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setColVisibility(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setColVisibilityIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setCombineAllColumns(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.Combiner
A convenience method to set the "all columns" option on a Combiner.
setCompactions(Map<String, TExternalCompaction>) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
setCompactionsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
setCompactor(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setCompactor(String) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setCompactor(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setCompactorIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setCompactorIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setCompactorIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setConditions(List<TCondition>) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
setConditionsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
setConfig(TSummarizerConfiguration) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setConfigId(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
setConfigIdIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
setConfigIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setConfigurer(PluginConfig) - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
Enables a CompactionConfigurer to run for this compaction on the server side.
setConsistencyLevel(ScannerBase.ConsistencyLevel) - Method in interface org.apache.accumulo.core.client.ScannerBase
Set the desired consistency level for this scanner.
setConsistencyLevel(ScannerBase.ConsistencyLevel) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
setConstrainClass(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setConstrainClassIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setCount(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setCountIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setCq(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setCq(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setCqIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setCreationDate(long) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setCreationDateIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setCredentials(Credentials) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
Update the credentials in the current context after changing the current user's password or other auth token
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setCredentials(TCredentials) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setCredentialsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setCryptoService(CryptoService) - Method in class org.apache.accumulo.core.file.rfile.bcfile.PrintBCInfo
 
setCurrent(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setCurrentIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setCurrentLog(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setCurrentLogIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setCurrentTime(IteratorSetting, Long) - Static method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
A convenience method for setting the current time (from which to measure the age off threshold).
setCv(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setCv(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setCve(ConstraintViolationException) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
setCveIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
setCvIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setData(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setData(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setDataCacheHits(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setDataCacheHitsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setDataCacheRequest(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setDataCacheRequestIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setDataCacheUsage(ScanDispatch.CacheUsage) - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch.Builder
If this is not called, then ScanDispatch.CacheUsage.TABLE should be used.
setDataIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setDateFormatSupplier(Supplier<DateFormat>) - Method in class org.apache.accumulo.core.util.format.FormatterConfig
this.dateFormatSupplier points to dateFormatSupplier, so it is recommended that you create a new Supplier when calling this function if your Supplier maintains some kind of state (see DateFormatSupplier.
setDeadTabletServers(List<DeadServer>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setDeadTabletServersIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setDeleted(boolean) - Method in class org.apache.accumulo.core.data.Key
Sets the delete marker on this key.
setDeleted(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setDeletedFiles(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setDeletedFilesIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setDeletedIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setDescription(String) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
setDescription(String) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
setDescription(String) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setDescription(String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
setDescription(String) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
setDescriptionIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
setDescriptionIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
setDescriptionIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setDescriptionIsSet(boolean) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
setDictionary(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
setDictionary(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
setDir(String) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setDirIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setDocColfPrefix(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
A convenience method for setting the document column family prefix.
setDurability(Durability) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Change the durability for the BatchWriter session.
setDurability(Durability) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Sets the Durability for the mutation, if applied.
setDurability(TDurability) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setDurability(TDurability) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
setDurability(TDurability) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setDurabilityIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setDurabilityIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
setDurabilityIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setElapsed(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setElapsedIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setEncoder(String) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Instantiates and sets the Encoder<V> used to translate Values to V and back.
setEncoder(Encoder<V>) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Sets the Encoder<V> used to translate Values to V and back.
setEncoding(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.RegExFilter
Set the encoding string to use when interpreting characters
setEncodingType(IteratorSetting, Class<? extends Encoder<Long>>) - Static method in class org.apache.accumulo.core.iterators.LongCombiner
A convenience method for setting the long encoding type.
setEncodingType(IteratorSetting, Class<? extends Encoder<List<Long>>>) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
A convenience method for setting the encoding type.
setEncodingType(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.LongCombiner
A convenience method for setting the long encoding type.
setEncodingType(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
A convenience method for setting the encoding type.
setEncodingType(IteratorSetting, LongCombiner.Type) - Static method in class org.apache.accumulo.core.iterators.LongCombiner
A convenience method for setting the long encoding type.
setEncodingType(IteratorSetting, SummingArrayCombiner.Type) - Static method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
A convenience method for setting the encoding type.
setEnd(IteratorSetting, long, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the end timestamp accepted by the timestamp filter.
setEnd(IteratorSetting, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the end timestamp accepted by the timestamp filter.
setEndRow(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setEndRow(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
setEndRow(byte[]) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setEndRow(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setEndRow(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setEndRow(Text) - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setEntries(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setEntries(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setEntries(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setEntriesIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setEntriesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setEntriesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setEntriesRead(long) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setEntriesRead(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setEntriesRead(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
setEntriesReadIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setEntriesReadIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setEntriesReadIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
setEntriesToBeCompacted(long) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setEntriesToBeCompactedIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setEntriesWritten(long) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setEntriesWritten(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setEntriesWritten(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
setEntriesWrittenIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setEntriesWrittenIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setEntriesWrittenIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
setEphemeralOwner(long) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooCache.ZcStat
 
setErrors(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setErrorsIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setEstimatedSize(long) - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
setEstimatedSizeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
setEx(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
setException(Span, Throwable, boolean) - Static method in class org.apache.accumulo.core.trace.TraceUtil
Record that an Exception occurred in the code covered by a Span
setExecutionHints(Map<String, String>) - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
setExecutionHints(Map<String, String>) - Method in interface org.apache.accumulo.core.client.ScannerBase
Set hints for the configured ScanPrioritizer and ScanDispatcher.
setExecutionHints(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
setExecutionHints(Map<String, String>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setExecutionHints(Map<String, String>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setExecutionHintsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setExecutionHintsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setExecutorName(String) - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch.Builder
If this is not called, then "default" should be used.
setExIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
setExpirationDate(long) - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
setExpirationDate(long) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setExpirationDate(long) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setExpirationDateIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setExpirationDateIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setExtent(TKeyExtent) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
setExtent(TKeyExtent) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setExtent(TKeyExtent) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setExtentIsSet(boolean) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
setExtentIsSet(boolean) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setExtentIsSet(boolean) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setExternalCompactionId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setExternalCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setFail(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setFailedExtents(Map<TKeyExtent, Long>) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
setFailedExtentsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
setFailIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setFailures(Map<TKeyExtent, List<TRange>>) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setFailuresIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setFieldValue(ClientService.authenticate_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
setFieldValue(ClientService.authenticate_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
setFieldValue(ClientService.authenticateUser_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
setFieldValue(ClientService.authenticateUser_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
setFieldValue(ClientService.changeAuthorizations_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setFieldValue(ClientService.changeAuthorizations_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
setFieldValue(ClientService.changeLocalUserPassword_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setFieldValue(ClientService.changeLocalUserPassword_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
setFieldValue(ClientService.checkClass_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setFieldValue(ClientService.checkClass_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
setFieldValue(ClientService.checkNamespaceClass_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setFieldValue(ClientService.checkNamespaceClass_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
setFieldValue(ClientService.checkTableClass_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setFieldValue(ClientService.checkTableClass_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
setFieldValue(ClientService.createLocalUser_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setFieldValue(ClientService.createLocalUser_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
setFieldValue(ClientService.dropLocalUser_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
setFieldValue(ClientService.dropLocalUser_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
setFieldValue(ClientService.getConfiguration_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
setFieldValue(ClientService.getConfiguration_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
setFieldValue(ClientService.getDiskUsage_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
setFieldValue(ClientService.getDiskUsage_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
setFieldValue(ClientService.getInstanceId_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
setFieldValue(ClientService.getInstanceId_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
setFieldValue(ClientService.getNamespaceConfiguration_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
setFieldValue(ClientService.getNamespaceConfiguration_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
setFieldValue(ClientService.getNamespaceProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
setFieldValue(ClientService.getNamespaceProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
setFieldValue(ClientService.getRootTabletLocation_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
setFieldValue(ClientService.getRootTabletLocation_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
setFieldValue(ClientService.getSystemProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
setFieldValue(ClientService.getSystemProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
setFieldValue(ClientService.getTableConfiguration_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
setFieldValue(ClientService.getTableConfiguration_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
setFieldValue(ClientService.getTableProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
setFieldValue(ClientService.getTableProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
setFieldValue(ClientService.getUserAuthorizations_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
setFieldValue(ClientService.getUserAuthorizations_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
setFieldValue(ClientService.getVersionedNamespaceProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
setFieldValue(ClientService.getVersionedNamespaceProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
setFieldValue(ClientService.getVersionedSystemProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
setFieldValue(ClientService.getVersionedSystemProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
setFieldValue(ClientService.getVersionedTableProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
setFieldValue(ClientService.getVersionedTableProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
setFieldValue(ClientService.getZooKeepers_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
setFieldValue(ClientService.getZooKeepers_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
setFieldValue(ClientService.grantNamespacePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setFieldValue(ClientService.grantNamespacePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
setFieldValue(ClientService.grantSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setFieldValue(ClientService.grantSystemPermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
setFieldValue(ClientService.grantTablePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setFieldValue(ClientService.grantTablePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
setFieldValue(ClientService.hasNamespacePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setFieldValue(ClientService.hasNamespacePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
setFieldValue(ClientService.hasSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setFieldValue(ClientService.hasSystemPermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
setFieldValue(ClientService.hasTablePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setFieldValue(ClientService.hasTablePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
setFieldValue(ClientService.isActive_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
setFieldValue(ClientService.isActive_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
setFieldValue(ClientService.listLocalUsers_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
setFieldValue(ClientService.listLocalUsers_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
setFieldValue(ClientService.ping_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
setFieldValue(ClientService.ping_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
setFieldValue(ClientService.revokeNamespacePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setFieldValue(ClientService.revokeNamespacePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
setFieldValue(ClientService.revokeSystemPermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setFieldValue(ClientService.revokeSystemPermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
setFieldValue(ClientService.revokeTablePermission_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setFieldValue(ClientService.revokeTablePermission_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
setFieldValue(TDiskUsage._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
setFieldValue(ThriftConcurrentModificationException._Fields, Object) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
setFieldValue(ThriftNotActiveServiceException._Fields, Object) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
setFieldValue(ThriftSecurityException._Fields, Object) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
setFieldValue(ThriftTableOperationException._Fields, Object) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setFieldValue(ThriftTest.fails_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
setFieldValue(ThriftTest.fails_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
setFieldValue(ThriftTest.success_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
setFieldValue(ThriftTest.success_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
setFieldValue(ThriftTest.throwsError_args._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
setFieldValue(ThriftTest.throwsError_result._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
setFieldValue(TInfo._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
setFieldValue(TVersionedProperties._Fields, Object) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
setFieldValue(CompactionCoordinatorService.cancel_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
setFieldValue(CompactionCoordinatorService.cancel_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
setFieldValue(CompactionCoordinatorService.compactionCompleted_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setFieldValue(CompactionCoordinatorService.compactionCompleted_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
setFieldValue(CompactionCoordinatorService.compactionFailed_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setFieldValue(CompactionCoordinatorService.compactionFailed_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
setFieldValue(CompactionCoordinatorService.getCompactionJob_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setFieldValue(CompactionCoordinatorService.getCompactionJob_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
setFieldValue(CompactionCoordinatorService.getCompletedCompactions_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
setFieldValue(CompactionCoordinatorService.getCompletedCompactions_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
setFieldValue(CompactionCoordinatorService.getRunningCompactions_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
setFieldValue(CompactionCoordinatorService.getRunningCompactions_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
setFieldValue(CompactionCoordinatorService.updateCompactionStatus_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setFieldValue(CompactionCoordinatorService.updateCompactionStatus_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
setFieldValue(CompactorService.cancel_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
setFieldValue(CompactorService.cancel_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
setFieldValue(CompactorService.getActiveCompactions_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
setFieldValue(CompactorService.getActiveCompactions_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
setFieldValue(CompactorService.getRunningCompaction_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
setFieldValue(CompactorService.getRunningCompaction_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
setFieldValue(CompactorService.getRunningCompactionId_args._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
setFieldValue(CompactorService.getRunningCompactionId_result._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
setFieldValue(TCompactionStatusUpdate._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setFieldValue(TExternalCompaction._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setFieldValue(TExternalCompactionList._Fields, Object) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
setFieldValue(UnknownCompactionIdException._Fields, Object) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
setFieldValue(InitialMultiScan._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
setFieldValue(InitialScan._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
setFieldValue(IterInfo._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
setFieldValue(MultiScanResult._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setFieldValue(ScanResult._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
setFieldValue(TCMResult._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
setFieldValue(TColumn._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
setFieldValue(TCondition._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setFieldValue(TConditionalMutation._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
setFieldValue(TConditionalSession._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
setFieldValue(TConstraintViolationSummary._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setFieldValue(TKey._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setFieldValue(TKeyExtent._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setFieldValue(TKeyValue._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
setFieldValue(TMutation._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setFieldValue(TRange._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setFieldValue(TRowRange._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
setFieldValue(TSummaries._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setFieldValue(TSummarizerConfiguration._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
setFieldValue(TSummary._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setFieldValue(TSummaryRequest._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setFieldValue(UpdateErrors._Fields, Object) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
setFieldValue(GcCycleStats._Fields, Object) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setFieldValue(GCMonitorService.getStatus_args._Fields, Object) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setFieldValue(GCMonitorService.getStatus_result._Fields, Object) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setFieldValue(GCStatus._Fields, Object) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setFieldValue(BulkImportStatus._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
setFieldValue(Compacting._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
setFieldValue(DeadServer._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
setFieldValue(FateService.beginFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
setFieldValue(FateService.beginFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
setFieldValue(FateService.cancelFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
setFieldValue(FateService.cancelFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
setFieldValue(FateService.executeFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setFieldValue(FateService.executeFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
setFieldValue(FateService.finishFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
setFieldValue(FateService.finishFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
setFieldValue(FateService.waitForFateOperation_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
setFieldValue(FateService.waitForFateOperation_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setFieldValue(ManagerClientService.getActiveTservers_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
setFieldValue(ManagerClientService.getActiveTservers_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
setFieldValue(ManagerClientService.getDelegationToken_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
setFieldValue(ManagerClientService.getDelegationToken_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
setFieldValue(ManagerClientService.getManagerStats_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
setFieldValue(ManagerClientService.getManagerStats_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
setFieldValue(ManagerClientService.initiateFlush_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
setFieldValue(ManagerClientService.initiateFlush_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setFieldValue(ManagerClientService.modifyNamespaceProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setFieldValue(ManagerClientService.modifyNamespaceProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setFieldValue(ManagerClientService.modifySystemProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
setFieldValue(ManagerClientService.modifySystemProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setFieldValue(ManagerClientService.modifyTableProperties_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setFieldValue(ManagerClientService.modifyTableProperties_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setFieldValue(ManagerClientService.removeNamespaceProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setFieldValue(ManagerClientService.removeNamespaceProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
setFieldValue(ManagerClientService.removeSystemProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
setFieldValue(ManagerClientService.removeSystemProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
setFieldValue(ManagerClientService.removeTableProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setFieldValue(ManagerClientService.removeTableProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
setFieldValue(ManagerClientService.reportSplitExtent_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setFieldValue(ManagerClientService.reportTabletStatus_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setFieldValue(ManagerClientService.setManagerGoalState_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setFieldValue(ManagerClientService.setManagerGoalState_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
setFieldValue(ManagerClientService.setNamespaceProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setFieldValue(ManagerClientService.setNamespaceProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setFieldValue(ManagerClientService.setSystemProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setFieldValue(ManagerClientService.setSystemProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setFieldValue(ManagerClientService.setTableProperty_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setFieldValue(ManagerClientService.setTableProperty_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setFieldValue(ManagerClientService.shutdown_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
setFieldValue(ManagerClientService.shutdown_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
setFieldValue(ManagerClientService.shutdownTabletServer_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setFieldValue(ManagerClientService.shutdownTabletServer_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
setFieldValue(ManagerClientService.waitForBalance_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
setFieldValue(ManagerClientService.waitForBalance_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
setFieldValue(ManagerClientService.waitForFlush_args._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setFieldValue(ManagerClientService.waitForFlush_result._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
setFieldValue(ManagerMonitorInfo._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setFieldValue(RecoveryStatus._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
setFieldValue(TableInfo._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setFieldValue(TabletServerStatus._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setFieldValue(TabletSplit._Fields, Object) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
setFieldValue(ThriftPropertyException._Fields, Object) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
setFieldValue(TAuthenticationKey._Fields, Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setFieldValue(TAuthenticationTokenIdentifier._Fields, Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setFieldValue(TCredentials._Fields, Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setFieldValue(TDelegationToken._Fields, Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
setFieldValue(TDelegationTokenConfig._Fields, Object) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
setFieldValue(TabletManagementClientService.chop_args._Fields, Object) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setFieldValue(TabletManagementClientService.flushTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setFieldValue(TabletManagementClientService.loadTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setFieldValue(TabletManagementClientService.splitTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setFieldValue(TabletManagementClientService.splitTablet_result._Fields, Object) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
setFieldValue(TabletManagementClientService.unloadTablet_args._Fields, Object) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setFieldValue(ConstraintViolationException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
setFieldValue(DataFileInfo._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
setFieldValue(TabletIngestClientService.applyUpdates_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setFieldValue(TabletIngestClientService.closeConditionalUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
setFieldValue(TabletIngestClientService.closeUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
setFieldValue(TabletIngestClientService.closeUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
setFieldValue(TabletIngestClientService.conditionalUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setFieldValue(TabletIngestClientService.conditionalUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
setFieldValue(TabletIngestClientService.invalidateConditionalUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
setFieldValue(TabletIngestClientService.invalidateConditionalUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
setFieldValue(TabletIngestClientService.loadFiles_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setFieldValue(TabletIngestClientService.startConditionalUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setFieldValue(TabletIngestClientService.startConditionalUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
setFieldValue(TabletIngestClientService.startUpdate_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
setFieldValue(TabletIngestClientService.startUpdate_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
setFieldValue(TabletIngestClientService.update_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setFieldValue(TabletIngestClientService.update_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
setFieldValue(ActiveScan._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setFieldValue(ScanServerBusyException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
setFieldValue(TabletScanClientService.closeMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
setFieldValue(TabletScanClientService.closeMultiScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
setFieldValue(TabletScanClientService.closeScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
setFieldValue(TabletScanClientService.continueMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
setFieldValue(TabletScanClientService.continueMultiScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setFieldValue(TabletScanClientService.continueScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
setFieldValue(TabletScanClientService.continueScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setFieldValue(TabletScanClientService.getActiveScans_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
setFieldValue(TabletScanClientService.getActiveScans_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
setFieldValue(TabletScanClientService.startMultiScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setFieldValue(TabletScanClientService.startMultiScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setFieldValue(TabletScanClientService.startScan_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setFieldValue(TabletScanClientService.startScan_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setFieldValue(TooManyFilesException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
setFieldValue(TSampleNotPresentException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
setFieldValue(TSamplerConfiguration._Fields, Object) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
setFieldValue(ActionStats._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setFieldValue(ActiveCompaction._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setFieldValue(InputFile._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setFieldValue(IteratorConfig._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
setFieldValue(NoSuchScanIDException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
setFieldValue(NotServingTabletException._Fields, Object) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
setFieldValue(TabletServerClientService.compact_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setFieldValue(TabletServerClientService.compactionJobFailed_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setFieldValue(TabletServerClientService.compactionJobFinished_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setFieldValue(TabletServerClientService.contiuneGetSummaries_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
setFieldValue(TabletServerClientService.contiuneGetSummaries_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
setFieldValue(TabletServerClientService.fastHalt_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
setFieldValue(TabletServerClientService.flush_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setFieldValue(TabletServerClientService.getActiveCompactions_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
setFieldValue(TabletServerClientService.getActiveCompactions_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
setFieldValue(TabletServerClientService.getActiveLogs_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
setFieldValue(TabletServerClientService.getActiveLogs_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
setFieldValue(TabletServerClientService.getCompactionQueueInfo_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
setFieldValue(TabletServerClientService.getCompactionQueueInfo_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
setFieldValue(TabletServerClientService.getHistoricalStats_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
setFieldValue(TabletServerClientService.getHistoricalStats_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
setFieldValue(TabletServerClientService.getTabletServerStatus_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
setFieldValue(TabletServerClientService.getTabletServerStatus_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
setFieldValue(TabletServerClientService.getTabletStats_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
setFieldValue(TabletServerClientService.getTabletStats_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
setFieldValue(TabletServerClientService.halt_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
setFieldValue(TabletServerClientService.halt_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
setFieldValue(TabletServerClientService.removeLogs_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
setFieldValue(TabletServerClientService.reserveCompactionJob_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setFieldValue(TabletServerClientService.reserveCompactionJob_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
setFieldValue(TabletServerClientService.startGetSummaries_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
setFieldValue(TabletServerClientService.startGetSummaries_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
setFieldValue(TabletServerClientService.startGetSummariesForPartition_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setFieldValue(TabletServerClientService.startGetSummariesForPartition_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
setFieldValue(TabletServerClientService.startGetSummariesFromFiles_args._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setFieldValue(TabletServerClientService.startGetSummariesFromFiles_result._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
setFieldValue(TabletStats._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setFieldValue(TCompactionQueueSummary._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
setFieldValue(TCompactionStats._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
setFieldValue(TExternalCompactionJob._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setFieldValue(TIteratorSetting._Fields, Object) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setFilename(String) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
setFilenameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
setFilenames(List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
setFilenamesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
setFiles(List<InputFile>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setFiles(Map<String, List<TRowRange>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setFiles(Map<TKeyExtent, Map<String, DataFileInfo>>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setFilesContaining(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setFilesContainingIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setFilesExceeding(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setFilesExceedingIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setFilesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setFilesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setFilesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setFileSize(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setFileSize(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
setFileSizeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setFileSizeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
setFilesLarge(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setFilesLargeIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setFinished(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setFinished(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setFinishedIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setFinishedIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setFlush(boolean) - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration.Builder
Determines if memory is flushed in the source table before cloning.
setFlush(boolean) - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
setFlush(boolean) - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
setFlushID(long) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setFlushIDIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setFlushs(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setFlushsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setForce(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setForceIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setFullScans(List<TKeyExtent>) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setFullScansIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setGoal(TUnloadTabletGoal) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setGoalIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setGoalState(ManagerGoalState) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setGoalStateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setHasTimestamp(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setHasTimestampIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setHeaders(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
setHeadersIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
setHoldTime(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setHoldTimeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setId(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
setIdentifier(TAuthenticationTokenIdentifier) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
setIdentifierIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
setIdIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
setIdleTime(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setIdleTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setIndexCacheHits(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setIndexCacheHitsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setIndexCacheRequest(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setIndexCacheRequestIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setIndexCacheUsage(ScanDispatch.CacheUsage) - Method in interface org.apache.accumulo.core.spi.scan.ScanDispatch.Builder
If this is not called, then ScanDispatch.CacheUsage.TABLE should be used.
setIndexColf(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.IndexedDocIterator
A convenience method for setting the index column family.
setInfiniteStartKey(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setInfiniteStartKeyIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setInfiniteStopKey(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setInfiniteStopKeyIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setIngestByteRate(double) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setIngestByteRateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setIngestRate(double) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setIngestRate(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setIngestRateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setIngestRateIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setInput(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressor
 
setInput(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityDecompressor
 
setInputFiles(List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setInputFilesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setInstanceId(String) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setInstanceId(String) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setInstanceId(InstanceId) - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
setInstanceIdIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setInstanceIdIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setInterfaceMatch(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setInterfaceMatch(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setInterfaceMatch(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setInterfaceMatchIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setInterfaceMatchIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setInterfaceMatchIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Reader
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.file.rfile.RFile.Reader
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.EmptyIterator
 
setInterruptFlag(AtomicBoolean) - Method in interface org.apache.accumulo.core.iteratorsImpl.system.InterruptibleIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.LocalityGroupIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SequenceFileIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
setInterruptFlag(AtomicBoolean) - Method in interface org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator.DataSource
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
setInterruptFlag(AtomicBoolean) - Method in class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
setInUse(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setInUseIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setIsolated(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setIsolatedIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setIssueDate(long) - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
setIssueDate(long) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setIssueDateIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setIteratorClass(String) - Method in class org.apache.accumulo.core.client.IteratorSetting
Set the name of the class that implements the iterator.
setIteratorClass(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setIteratorClassIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setIterators(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setIterators(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setIterators(List<IteratorSetting>) - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
setIterators(List<TIteratorSetting>) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
setIterators(IteratorSetting...) - Method in class org.apache.accumulo.core.data.Condition
Set iterators to use when reading the columns value.
setIteratorSamplerConfiguration(SamplerConfiguration) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
This is provided for the case where no sampler configuration is set on the scanner, but there is a need to create iterator deep copies that have sampling enabled.
setIteratorSettings(IteratorConfig) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setIteratorSettingsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setIteratorsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setIteratorsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
setIterName(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
setIterNameIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
setJob(TExternalCompactionJob) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setJobIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setKeepMappings(boolean) - Method in interface org.apache.accumulo.core.client.admin.ImportConfiguration.Builder
During the table import transaction, an intermediate Constants.IMPORT_MAPPINGS_FILE file is created and usually removed after the import process is completed.
setKeepMappings(boolean) - Method in class org.apache.accumulo.core.clientImpl.ImportConfigurationImpl
 
setKeepOffline(boolean) - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration.Builder
The new table is normally brought online after the cloning process.
setKeepOffline(boolean) - Method in interface org.apache.accumulo.core.client.admin.ImportConfiguration.Builder
The new table is normally brought online after the import process.
setKeepOffline(boolean) - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
setKeepOffline(boolean) - Method in class org.apache.accumulo.core.clientImpl.ImportConfigurationImpl
 
setKerberosKeytab(Properties, String) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
setKey(TKey) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
setKeyExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setKeyExtent(TKeyExtent) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setKeyExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setKeyExtentIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setKeyId(int) - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
setKeyId(int) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setKeyId(int) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setKeyIdIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setKeyIdIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setKeyIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
setKeyStoreFromConf(AccumuloConfiguration) - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
setKind(TCompactionKind) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setKindIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setLast(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setLastContact(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setLastContactIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setLastIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setLastLog(GcCycleStats) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setLastLogIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
setLastStatus(long) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
setLastStatusIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
setLength(int) - Method in class org.apache.accumulo.core.util.MutableByteSequence
 
setLifetime(long) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
setLifetimeIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
setLocalityGroup(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setLocalityGroupIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setLocalityGroups(String, Map<String, Set<Text>>) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Sets a table's locality groups.
setLocalityGroups(String, Map<String, Set<Text>>) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
setLocalityGroups(Map<String, Set<Text>>) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Configures a table's locality groups prior to initial table creation.
setLock(String) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setLock(String) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setLock(String) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setLock(String) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setLock(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setLockIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
setLogSorts(List<RecoveryStatus>) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setLogSortsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setLookups(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setLookupsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setLossyness(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.TypedValueCombiner
A convenience method to set the "lossy" option on a TypedValueCombiner.
setMajors(Compacting) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setMajors(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMajorsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setMajorsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setManagerGoalState() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setManagerGoalState
 
setManagerGoalState() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setManagerGoalState
 
setManagerGoalState(TInfo, TCredentials, ManagerGoalState) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
setManagerGoalState(TInfo, TCredentials, ManagerGoalState) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
setManagerGoalState(TInfo, TCredentials, ManagerGoalState, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
setManagerGoalState(TInfo, TCredentials, ManagerGoalState, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
setManagerGoalState_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setManagerGoalState_args(TInfo, TCredentials, ManagerGoalState) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setManagerGoalState_args(ManagerClientService.setManagerGoalState_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
Performs a deep copy on other.
setManagerGoalState_call(TInfo, TCredentials, ManagerGoalState, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setManagerGoalState_call
 
setManagerGoalState_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
setManagerGoalState_result(ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
setManagerGoalState_result(ManagerClientService.setManagerGoalState_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
Performs a deep copy on other.
setMaxBufferSize(IteratorSetting, long) - Static method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Configure the maximum amount of memory that can be used for transformation.
setMaxColumns(IteratorSetting, int) - Static method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
A convenience method for setting the maximum number of columns to keep.
setMaxLatency(long, TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Sets the maximum amount of time to hold the data in memory before flushing it to servers.
For no maximum, set to zero, or Long.MAX_VALUE with TimeUnit.MILLISECONDS.
setMaxLoops(long) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setMaxLoopsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setMaxMemory(long) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Sets the maximum memory to batch before writing.
setMaxVersions(IteratorSetting, int) - Static method in class org.apache.accumulo.core.iterators.user.VersioningIterator
Encode the maximum number of versions to return onto the ScanIterator
setMaxWriteThreads(int) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Sets the maximum number of threads to use for writing data to the tablet servers.
setMaxWriteThreads(int) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Sets the maximum number of threads to use for writing data to the tablet servers.
setMessage(String) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setMessageIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setMetadataFileEntry(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setMetadataFileEntryIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setMigrations(Set<TabletId>) - Method in interface org.apache.accumulo.core.spi.balancer.util.ThrottledBalancerProblemReporter.OutstandingMigrationsProblem
 
setMinors(Compacting) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setMinors(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMinorsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setMinorsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setMode(SingletonManager.Mode) - Static method in class org.apache.accumulo.core.singletons.SingletonManager
Change how singletons are managed.
setModulus(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setModulusIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setMore(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setMore(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
setMoreIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setMoreIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
setMutation(TMutation) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
setMutation(TMutation) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setMutationIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
setMutationIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setMutations(List<TMutation>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setMutations(Map<TKeyExtent, List<TConditionalMutation>>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setMutationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setMutationsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setName(String) - Method in class org.apache.accumulo.core.client.IteratorSetting
Set the iterator's name.
setName(String) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
setName(String) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
setName(String) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setName(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setNamedOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
setNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
setNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setNameIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setNamespaceId(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setNamespaceIdIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setNamespaceProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setNamespaceProperty
 
setNamespaceProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setNamespaceProperty
 
setNamespaceProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
setNamespaceProperty(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
setNamespaceProperty(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
setNamespaceProperty(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
setNamespaceProperty_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setNamespaceProperty_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setNamespaceProperty_args(ManagerClientService.setNamespaceProperty_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
Performs a deep copy on other.
setNamespaceProperty_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setNamespaceProperty_call
 
setNamespaceProperty_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setNamespaceProperty_result(ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException, ThriftPropertyException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setNamespaceProperty_result(ManagerClientService.setNamespaceProperty_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
Performs a deep copy on other.
setNegate(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.Filter
A convenience method for setting the negation option on a filter.
setNewTablets(List<TKeyExtent>) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
setNewTabletsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
setNs(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
setNs(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
setNs(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
setNs(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setNs(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setNs(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setNs(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setNs(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setNs(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setNsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setNssi(NoSuchScanIDException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setNssiIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
setNste(NotServingTabletException) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
setNste(NotServingTabletException) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
setNste(NotServingTabletException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setNste(NotServingTabletException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setNsteIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
setNsteIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
setNsteIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setNsteIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setNum(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setNumberOfViolatingMutations(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setNumberOfViolatingMutationsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setNumEntries(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setNumEntriesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setNumIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setNumScansBeforeSeek(IteratorSetting, int) - Static method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
convenience method to set the option to optimize the frequency of scans vs.
setOldTablet(TKeyExtent) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
setOldTabletIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
setOnlineTabletCount(int) - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
setOnlineTablets(int) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setOnlineTabletsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setOp(TableOperation) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setOp(FateOperation) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setOpid(long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
setOpid(long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setOpid(long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
setOpid(long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
setOpidIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
setOpidIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setOpidIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
setOpidIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
setOpIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setOpIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setOptions(Map<String, String>) - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
setOptions(Map<String, String>) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
setOptions(Map<String, String>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setOptions(Map<String, String>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
setOptions(ScannerOptions, ScannerOptions) - Static method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
setOptionsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
setOptionsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setOptionsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
setOsLoad(double) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setOsLoadIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setOutputFile(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setOutputFile(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setOutputFileIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setOutputFileIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setOverrides(Map<String, String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setOverridesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setPartNextKey(TKey) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setPartNextKeyInclusive(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setPartNextKeyInclusiveIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setPartNextKeyIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setPartScan(TKeyExtent) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setPartScanIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setPassword(byte[]) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
setPassword(ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setPassword(ByteBuffer) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setPassword(ByteBuffer) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
setPassword(CharBuffer) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
setPassword(Properties, CharSequence) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setPasswordIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
setPath(Configuration, String) - Static method in class org.apache.accumulo.core.conf.HadoopCredentialProvider
Set the Hadoop Credential Provider path in the provided Hadoop Configuration.
setPermission(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setPermission(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setPermissionIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setPrevEndRow(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setPrevEndRow(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setPrevEndRowIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setPrevKey(Key) - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setPrincipal(String) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setPrincipal(String) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
setPrincipalIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setPrintTimestamps(boolean) - Method in class org.apache.accumulo.core.util.format.FormatterConfig
 
setPriority(int) - Method in class org.apache.accumulo.core.client.IteratorSetting
Set layer at which this iterator applies.
setPriority(int) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
setPriority(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setPriority(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setPriority(short) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
setPriorityIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
setPriorityIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setPriorityIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
setPriorityIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setProgress(double) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
setProgressIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
setPropagateDeletes(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setPropagateDeletesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setProperties(Map<String, String>) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Sets additional properties to be applied to tables created with this configuration.
setProperties(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
setProperties(Map<String, String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setPropertiesIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
setPropertiesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
setPropertiesToExclude(Set<String>) - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration.Builder
The source table properties are copied, this allows reverting to system defaults for some of those properties.
setPropertiesToExclude(Set<String>) - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
setPropertiesToSet(Map<String, String>) - Method in interface org.apache.accumulo.core.client.admin.CloneConfiguration.Builder
The source table properties are copied.
setPropertiesToSet(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
setProperty(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setProperty(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setProperty(String) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
setProperty(String, String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Sets a system property in zookeeper.
setProperty(String, String) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
setProperty(String, String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Sets a property on a namespace which applies to all tables in the namespace.
setProperty(String, String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Sets a property on a table.
setProperty(String, String, String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
setProperty(String, String, String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
setProperty(ClientProperty, CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
setProperty(ClientProperty, Integer) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
setProperty(ClientProperty, Long) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
setPropertyId(String) - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration.Builder
Sets the id used when generating table properties.
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setPropertyIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setPropertyIsSet(boolean) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
setQueryByteRate(double) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setQueryByteRateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setQueryRate(double) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setQueryRate(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setQueryRateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setQueryRateIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setQueue(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
setQueued(int) - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
setQueuedIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
setQueueIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
setQueueName(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setQueueName(String) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setQueueName(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setQueueNameIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setQueueNameIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setQueueNameIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setQueueSumDev(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueTime(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setQueueTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setRange(IteratorSetting, long, boolean, long, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the range of timestamps accepted by the timestamp filter.
setRange(IteratorSetting, long, long) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the range of timestamps accepted by the timestamp filter.
setRange(IteratorSetting, String, boolean, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the range of timestamps accepted by the timestamp filter.
setRange(IteratorSetting, String, String) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the range of timestamps accepted by the timestamp filter.
setRange(Range) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
setRange(Range) - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
setRange(Range) - Method in interface org.apache.accumulo.core.client.Scanner
Sets the range of keys to scan over.
setRange(Range) - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
setRange(Range) - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
setRange(TRange) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setRangeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setRanges(Collection<Range>) - Method in interface org.apache.accumulo.core.client.BatchDeleter
Allows deleting multiple ranges efficiently.
setRanges(Collection<Range>) - Method in interface org.apache.accumulo.core.client.BatchScanner
Allows scanning over multiple ranges efficiently.
setRanges(Collection<Range>) - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchReader
 
setRate(long) - Method in class org.apache.accumulo.core.util.ratelimit.GuavaRateLimiter
Change the rate at which permits are made available.
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
 
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.client.IsolatedScanner
 
setReadaheadThreshold(long) - Method in interface org.apache.accumulo.core.client.Scanner
Sets the number of batches of Key/Value pairs returned before the Scanner will begin to prefetch the next batch
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.clientImpl.OfflineScanner
 
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.clientImpl.ScannerImpl
 
setReadaheadThreshold(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setReadaheadThresholdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setReason(TCompactionReason) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setReasonIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setRecs(long) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setRecsInMemory(long) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setRecsInMemoryIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setRecsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setReduceOnFullCompactionOnly(IteratorSetting, boolean) - Static method in class org.apache.accumulo.core.iterators.Combiner
Combiners may not work correctly with deletes.
setRegexs(IteratorSetting, String, String, String, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.RegExFilter
Encode the terms to match against in the iterator.
setRegexs(IteratorSetting, String, String, String, String, boolean, boolean) - Static method in class org.apache.accumulo.core.iterators.user.RegExFilter
Encode the terms to match against in the iterator
setRemainder(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setRemainderIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setRenameMap(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.bulk.LoadMappingIterator
 
setRequest(TSummaryRequest) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
setRequest(TSummaryRequest) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setRequest(TSummaryRequest) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setRequestIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
setRequestIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setRequestIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setRequestTime(long) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setRequestTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setResponseTime(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setResponseTimeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setResult(MultiScanResult) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
setResult(ScanResult) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
setResultIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
setResultIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
setResults(List<TKeyValue>) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setResults(List<TKeyValue>) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
setResultsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
setResultsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
setRow(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setRow(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setRow(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setRow(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setRowIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setRowIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setRunning(int) - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
setRunningIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
setRuntime(int) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
setRuntimeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
setSampleBufferSize(int) - Static method in class org.apache.accumulo.core.file.rfile.RFile
 
setSamplerConfig(TSamplerConfiguration) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setSamplerConfig(TSamplerConfiguration) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setSamplerConfigIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setSamplerConfigIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setSamplerConfiguration(String, SamplerConfiguration) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Set or update the sampler configuration for a table.
setSamplerConfiguration(String, SamplerConfiguration) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
setSamplerConfiguration(SamplerConfiguration) - Method in interface org.apache.accumulo.core.client.ScannerBase
Setting this will cause the scanner to read sample data, as long as that sample data was generated with the given configuration.
setSamplerConfiguration(SamplerConfiguration) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
setScanId(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setScanID(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
setScanID(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
setScanID(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
setScanID(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
setScanID(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
setScanID(long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
setScanIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
setScanIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
setScanRate(double) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setScanRateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setScans(Compacting) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setScansIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
setSec(ThriftSecurityException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
setSecIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
setSecret(byte[]) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setSecret(ByteBuffer) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setSecretIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
setSelector(PluginConfig) - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
Configure a CompactionSelector plugin to run for this compaction.
setServ(String) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
setServer(String) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
setServerIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
setServerName(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setServerName(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setServerNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setServerNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setServersShuttingDown(Set<String>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setServersShuttingDownIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setServIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
setSessID(long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
setSessID(long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setSessID(long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
setSessIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
setSessIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setSessIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
setSessionId(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
setSessionId(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setSessionId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
setSessionIdIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
setSessionIdIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setSessionIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
setSetTime(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setSetTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setShownLength(int) - Method in class org.apache.accumulo.core.util.format.FormatterConfig
If given a negative number, throws an IllegalArgumentException
setSize(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setSizeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setSlice(IteratorSetting, String, boolean, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
setSlice(IteratorSetting, String, String) - Static method in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
setSource(Scanner) - Method in class org.apache.accumulo.core.client.ClientSideIteratorScanner
Sets the source Scanner.
setSource(SortedKeyValueIterator<Key, Value>) - Method in class org.apache.accumulo.core.iterators.WrappingIterator
 
setSources(List<String>) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setSourcesIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setSplit(TabletSplit) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setSplitCreationTime(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitCreationTimeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setSplitPoint(byte[]) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setSplitPoint(ByteBuffer) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setSplitPointIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setSplits(ActionStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSplitsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
setSsbe(ScanServerBusyException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setSsbe(ScanServerBusyException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setSsbe(ScanServerBusyException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setSsbe(ScanServerBusyException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setSsbeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setSsbeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setSsbeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setSsbeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setSsiList(List<IterInfo>) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setSsiList(List<IterInfo>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setSsiList(List<IterInfo>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setSsiList(List<IterInfo>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setSsiListIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setSsiListIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setSsiListIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setSsiListIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setSsio(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setSsio(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setSsio(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setSsio(Map<String, Map<String, String>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setSsioIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setSsioIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setSsioIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setSsioIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setStart(IteratorSetting, long, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the start timestamp accepted by the timestamp filter.
setStart(IteratorSetting, String, boolean) - Static method in class org.apache.accumulo.core.iterators.user.TimestampFilter
A convenience method for setting the start timestamp accepted by the timestamp filter.
setStart(TKey) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setStarted(long) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setStartedIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
setStartIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setStartKeyInclusive(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setStartKeyInclusiveIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setStartRow(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
setStartRow(byte[]) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setStartRow(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setStartRow(byte[]) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setStartRow(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
setStartRow(ByteBuffer) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setStartRow(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setStartRow(ByteBuffer) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setStartRow(Text) - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
setStartRowIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
setStartRowIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setStartRowIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setStartRowIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setStartTime(long) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
setStartTimeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
setState(TCompactionState) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setState(BulkImportState) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
setState(ManagerGoalState) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setState(ManagerState) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setState(ScanState) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setStateIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
setStateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
setStateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setStateIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setStateIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setStats(TCompactionStats) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setStatsIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setStatus(int) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setStatus(long, ReadOnlyTStore.TStatus) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
setStatus(long, ReadOnlyTStore.TStatus) - Method in interface org.apache.accumulo.core.fate.TStore
Update the state of a given transaction
setStatus(long, ReadOnlyTStore.TStatus) - Method in class org.apache.accumulo.core.fate.ZooStore
 
setStatus(String) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
setStatus(TCompactionStatusUpdate) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setStatus(TCMStatus) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
setStatus(TabletLoadState) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setStatusIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setStop(TKey) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setStopIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setStopKeyInclusive(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setStopKeyInclusiveIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
setStopTabletServers(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
setStopTabletServersIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
setSuccess(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
setSuccess(long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
setSuccess(long) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setSuccess(long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
setSuccess(String) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setSuccess(List<String>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
setSuccess(List<String>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
setSuccess(List<ByteBuffer>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
setSuccess(List<TDiskUsage>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
setSuccess(List<TCMResult>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
setSuccess(List<ActiveScan>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
setSuccess(List<ActiveCompaction>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
setSuccess(List<ActiveCompaction>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
setSuccess(List<TabletStats>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
setSuccess(List<TCompactionQueueSummary>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
setSuccess(Map<String, String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
setSuccess(Set<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
setSuccess(TVersionedProperties) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
setSuccess(TVersionedProperties) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
setSuccess(TVersionedProperties) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
setSuccess(TExternalCompactionList) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
setSuccess(TExternalCompactionList) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
setSuccess(InitialMultiScan) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setSuccess(InitialScan) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setSuccess(MultiScanResult) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setSuccess(ScanResult) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setSuccess(TConditionalSession) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
setSuccess(TSummaries) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
setSuccess(TSummaries) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
setSuccess(TSummaries) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
setSuccess(TSummaries) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
setSuccess(UpdateErrors) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
setSuccess(GCStatus) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSuccess(ManagerMonitorInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
setSuccess(TabletServerStatus) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
setSuccess(TDelegationToken) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
setSuccess(TabletStats) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
setSuccess(TExternalCompactionJob) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
setSuccess(TExternalCompactionJob) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
setSuccess(TExternalCompactionJob) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
setSuccessIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
setSumDev(double) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setSumDevIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
setSummaries(List<TSummary>) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setSummariesIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setSummarizerPattern(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setSummarizerPatternIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setSummarizers(List<TSummarizerConfiguration>) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setSummarizersIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setSummary(Map<String, Long>) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setSummaryIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
setSymbols(List<String>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setSymbolsIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setSyncs(long) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setSyncsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setSysPerm(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setSysPermIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setSystemProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setSystemProperty
 
setSystemProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setSystemProperty
 
setSystemProperty(TInfo, TCredentials, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
setSystemProperty(TInfo, TCredentials, String, String) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
setSystemProperty(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
setSystemProperty(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
setSystemProperty_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setSystemProperty_args(TInfo, TCredentials, String, String) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setSystemProperty_args(ManagerClientService.setSystemProperty_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
Performs a deep copy on other.
setSystemProperty_call(TInfo, TCredentials, String, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setSystemProperty_call
 
setSystemProperty_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setSystemProperty_result(ThriftSecurityException, ThriftNotActiveServiceException, ThriftPropertyException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setSystemProperty_result(ManagerClientService.setSystemProperty_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
Performs a deep copy on other.
setTable(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setTable(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setTableId(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setTableId(String) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setTableId(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setTableId(String) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setTableId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setTableId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setTableId(String) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
setTableID(String) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setTableIdIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setTableIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
setTableIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setTableInfo(String) - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
setTableIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
setTableMap(Map<String, TableInfo>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setTableMap(Map<String, TableInfo>) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setTableMap(Map<String, TableStatistics>) - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
setTableMapIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setTableMapIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setTableName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
setTableName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
setTableName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
setTableName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setTableName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setTableName(String) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setTableName(String) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setTableName(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
setTableName(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setTableName(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setTableName(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setTableName(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setTableNameIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setTableNameIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setTableProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setTableProperty
 
setTableProperty() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.setTableProperty
 
setTableProperty(TInfo, TCredentials, String, String, String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
setTableProperty(TInfo, TCredentials, String, String, String) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
setTableProperty(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
setTableProperty(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
setTableProperty_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setTableProperty_args(TInfo, TCredentials, String, String, String) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setTableProperty_args(ManagerClientService.setTableProperty_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
Performs a deep copy on other.
setTableProperty_call(TInfo, TCredentials, String, String, String, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setTableProperty_call
 
setTableProperty_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setTableProperty_result(ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException, ThriftPropertyException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setTableProperty_result(ManagerClientService.setTableProperty_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
Performs a deep copy on other.
setTables(List<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
setTables(Set<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
setTablesIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
setTablesIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
setTablet(TKeyExtent) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setTabletIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setTablets(int) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setTabletServer(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setTabletServerIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setTabletsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
setTblNspcPerm(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setTblNspcPermIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setTblPerm(byte) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setTblPermIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setTcme(ThriftConcurrentModificationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setTcme(ThriftConcurrentModificationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setTcme(ThriftConcurrentModificationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setTcmeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setTcmeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setTcmeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setTerm(IteratorSetting, String) - Static method in class org.apache.accumulo.core.iterators.user.GrepIterator
Encode the grep term as an option for a ScanIterator
setTerms(SortedKeyValueIterator<Key, Value>, Collection<String>, IteratorEnvironment) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
setTid(long) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
setTid(long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
setTidIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setTime - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setTime(long) - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
setTimeInMillis(Properties, Long) - Method in enum org.apache.accumulo.core.conf.ClientProperty
 
setTimeout(long, TimeUnit) - Method in interface org.apache.accumulo.core.client.BatchScanner
This setting determines how long a scanner will automatically retry when a failure occurs.
setTimeout(long, TimeUnit) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
Sets the maximum amount of time an unresponsive server will be re-tried.
setTimeout(long, TimeUnit) - Method in class org.apache.accumulo.core.client.ConditionalWriterConfig
Sets the maximum amount of time an unresponsive server will be re-tried.
setTimeout(long, TimeUnit) - Method in interface org.apache.accumulo.core.client.ScannerBase
This setting determines how long a scanner will automatically retry when a failure occurs.
setTimeout(long, TimeUnit) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
setTimesPaused(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setTimesPausedIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setTimestamp(long) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setTimestamp(long) - Method in class org.apache.accumulo.core.data.Condition
Sets the version for the column to check.
setTimestamp(long) - Method in class org.apache.accumulo.core.data.Key
Sets the timestamp.
setTimestamp(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setTimestamp(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setTimestampIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setTimestampIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
setTimestampIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
setTimeType(TimeType) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Configure logical or millisecond time for tables created with this configuration.
setTimeZone(TimeZone) - Method in class org.apache.accumulo.core.util.format.DateFormatSupplier
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setTinfo(TInfo) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
setTinfoIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
setTmfe(TooManyFilesException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setTmfe(TooManyFilesException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setTmfeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setTmfeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
setTnase(ThriftNotActiveServiceException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
setTnaseIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
setToAuth(TCredentials) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
setToAuthIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
setToe(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
setToeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
setToken(byte[]) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setToken(ByteBuffer) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setTokenClassName(String) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setTokenClassNameIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setTokenIsSet(boolean) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
setTokenLifetime(long, TimeUnit) - Method in class org.apache.accumulo.core.client.admin.DelegationTokenConfig
Requests a specific lifetime for the token that is different from the default system lifetime.
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
setTope(ThriftTableOperationException) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
setTopeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
setTotalFiles(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setTotalFilesIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
setTpe(ThriftPropertyException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setTpe(ThriftPropertyException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setTpe(ThriftPropertyException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setTpe(ThriftPropertyException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setTpe(ThriftPropertyException) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setTpeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
setTpeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
setTpeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
setTpeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
setTpeIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
setTransactionInfo(long, Fate.TxInfo, Serializable) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
setTransactionInfo(long, Fate.TxInfo, Serializable) - Method in interface org.apache.accumulo.core.fate.TStore
Set transaction-specific information.
setTransactionInfo(long, Fate.TxInfo, Serializable) - Method in class org.apache.accumulo.core.fate.ZooStore
 
setTrustStoreFromConf(AccumuloConfiguration) - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
setTs(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setTServerInfo(List<TabletServerStatus>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setTServerInfoIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setTserverLock(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
setTserverLockIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
setTsIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setTsnpe(TSampleNotPresentException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setTsnpe(TSampleNotPresentException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setTsnpe(TSampleNotPresentException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setTsnpe(TSampleNotPresentException) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setTsnpeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
setTsnpeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
setTsnpeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
setTsnpeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
setTtl(long) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
setTTL(IteratorSetting, Long) - Static method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
A convenience method for setting the age off threshold.
setTtlIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
setType(ConfigurationType) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
setType(TableOperationExceptionType) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setType(ScanType) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setType(TCompactionType) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setTypeIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
setTypeIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
setTypeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setTypeIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
setUnassignedTablets(int) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setUnassignedTabletsIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
setUnnamedOptionDescriptions(List<String>) - Method in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
setUpdateID(long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setUpdateID(long) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
setUpdateIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
setUpdateIDIsSet(boolean) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
setUpdates(Map<Long, TCompactionStatusUpdate>) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setUpdatesIsSet(boolean) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
setupSystemScanIterators(SortedKeyValueIterator<Key, Value>, Set<Column>, Authorizations, byte[], AccumuloConfiguration) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.SystemIteratorUtil
 
setUsage(long) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
setUsageIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
setUseJsse(boolean) - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
setUser(String) - Method in exception org.apache.accumulo.core.client.AccumuloSecurityException
 
setUser(String) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
setUser(String) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setUserCompactionId(long) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setUserCompactionIdIsSet(boolean) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
setUserIsSet(boolean) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
setUserIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
setVal(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setVal(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setValIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
setValue(byte[]) - Method in class org.apache.accumulo.core.data.Condition
This method sets the expected value of a column.
setValue(byte[]) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
setValue(CharSequence) - Method in class org.apache.accumulo.core.data.Condition
This method sets the expected value of a column.
setValue(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setValue(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setValue(String) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setValue(String) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
setValue(ByteBuffer) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
setValue(ByteSequence) - Method in class org.apache.accumulo.core.data.Condition
This method sets the expected value of a column.
setValue(Text) - Method in class org.apache.accumulo.core.data.Condition
This method sets the expected value of a column.
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
setValueIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
setValueIsSet(boolean) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
setValues(List<ByteBuffer>) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setValuesIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
setVersion(long) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
setVersion(String) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setVersionIsSet(boolean) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
setVersionIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
setViolationCode(short) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setViolationCodeIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setViolationDescription(String) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setViolationDescriptionIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
setViolationSummaries(List<TConstraintViolationSummary>) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
setViolationSummaries(List<TConstraintViolationSummary>) - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
setViolationSummariesIsSet(boolean) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
setViolationSummariesIsSet(boolean) - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
setVisibility(ColumnVisibility) - Method in class org.apache.accumulo.core.data.Condition
Sets the visibility for the column to check.
setVProperties(TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setVProperties(TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
setVProperties(TVersionedProperties) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setVPropertiesIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
setVPropertiesIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
setVPropertiesIsSet(boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
setWait(boolean) - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
setWaitForWrites(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setWaitForWrites(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setWaitForWritesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
setWaitForWritesIsSet(boolean) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
setWithCredentialProviders(String, String) - Method in class org.apache.accumulo.core.client.security.tokens.CredentialProviderToken
 
SF_EXTRA_SUMMARY - org.apache.accumulo.core.compaction.CompactionSettings
 
SF_GT_ESIZE_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
SF_LT_ESIZE_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
SF_NAME_RE_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
SF_NO_SAMPLE - org.apache.accumulo.core.compaction.CompactionSettings
 
SF_NO_SUMMARY - org.apache.accumulo.core.compaction.CompactionSettings
 
SF_PATH_RE_OPT - org.apache.accumulo.core.compaction.CompactionSettings
 
ShardedTableDistributionFormatter - Class in org.apache.accumulo.core.util.format
Formats the rows in a METADATA table scan to show distribution of shards over servers per day.
ShardedTableDistributionFormatter() - Constructor for class org.apache.accumulo.core.util.format.ShardedTableDistributionFormatter
 
SharedRateLimiterFactory - Class in org.apache.accumulo.core.util.ratelimit
Provides the ability to retrieve a RateLimiter keyed to a specific string, which will dynamically update its rate according to a specified callback function.
SharedRateLimiterFactory.RateProvider - Interface in org.apache.accumulo.core.util.ratelimit
A callback which provides the current rate for a RateLimiter.
SharedRateLimiterFactory.SharedRateLimiter - Class in org.apache.accumulo.core.util.ratelimit
 
ShellCompactCommandConfigurer - Class in org.apache.accumulo.core.compaction
The compaction configurer is used by the shell compact command.
ShellCompactCommandConfigurer() - Constructor for class org.apache.accumulo.core.compaction.ShellCompactCommandConfigurer
 
ShellCompactCommandSelector - Class in org.apache.accumulo.core.compaction
The compaction selector is used by the shell compact command.
ShellCompactCommandSelector() - Constructor for class org.apache.accumulo.core.compaction.ShellCompactCommandSelector
 
shorten(ByteSequence, ByteSequence) - Static method in class org.apache.accumulo.core.file.rfile.KeyShortener
 
shorten(Key, Key) - Static method in class org.apache.accumulo.core.file.rfile.KeyShortener
 
shouldBalance(SortedMap<TabletServerId, TServerStatus>, Set<TabletId>) - Method in class org.apache.accumulo.core.spi.balancer.GroupBalancer
 
shutdown() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdown
 
shutdown() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdown
 
shutdown() - Method in class org.apache.accumulo.core.fate.Fate
Flags that FATE threadpool to clear out and end.
shutdown() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
 
shutdown(TInfo, TCredentials, boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
shutdown(TInfo, TCredentials, boolean) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
shutdown(TInfo, TCredentials, boolean, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
shutdown(TInfo, TCredentials, boolean, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
shutdown_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
shutdown_args(TInfo, TCredentials, boolean) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
shutdown_args(ManagerClientService.shutdown_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
Performs a deep copy on other.
shutdown_call(TInfo, TCredentials, boolean, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.shutdown_call
 
shutdown_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
shutdown_result(ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
shutdown_result(ManagerClientService.shutdown_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
Performs a deep copy on other.
shutdownTabletServer() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdownTabletServer
 
shutdownTabletServer() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.shutdownTabletServer
 
shutdownTabletServer(TInfo, TCredentials, String, boolean) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
shutdownTabletServer(TInfo, TCredentials, String, boolean) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
shutdownTabletServer(TInfo, TCredentials, String, boolean, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
shutdownTabletServer(TInfo, TCredentials, String, boolean, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
shutdownTabletServer_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
shutdownTabletServer_args(TInfo, TCredentials, String, boolean) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
shutdownTabletServer_args(ManagerClientService.shutdownTabletServer_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
Performs a deep copy on other.
shutdownTabletServer_call(TInfo, TCredentials, String, boolean, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.shutdownTabletServer_call
 
shutdownTabletServer_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
shutdownTabletServer_result(ThriftSecurityException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
shutdownTabletServer_result(ManagerClientService.shutdownTabletServer_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
Performs a deep copy on other.
shutdownThreadPoolExecutor(ExecutorService, AtomicBoolean, Logger) - Static method in class org.apache.accumulo.core.util.cleaner.CleanerUtil
 
ShutdownUtil - Class in org.apache.accumulo.core.util
 
ShutdownUtil() - Constructor for class org.apache.accumulo.core.util.ShutdownUtil
 
SimpleCompactionDispatcher - Class in org.apache.accumulo.core.spi.compaction
Dispatcher that supports simple configuration for making tables use compaction services.
SimpleCompactionDispatcher() - Constructor for class org.apache.accumulo.core.spi.compaction.SimpleCompactionDispatcher
 
SimpleLoadBalancer - Class in org.apache.accumulo.core.spi.balancer
A simple tablet balancer that attempts to spread tablets out evenly across all available tablet servers.
SimpleLoadBalancer() - Constructor for class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
SimpleLoadBalancer(TableId) - Constructor for class org.apache.accumulo.core.spi.balancer.SimpleLoadBalancer
 
SimpleScanDispatcher - Class in org.apache.accumulo.core.spi.scan
If no options are given, then this will default to an executor named default and ScanDispatch.CacheUsage.TABLE for index and data cache.
SimpleScanDispatcher() - Constructor for class org.apache.accumulo.core.spi.scan.SimpleScanDispatcher
 
SINGLE - org.apache.accumulo.core.client.admin.ScanType
 
SINGLE - org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock.BlockPriority
Accessed a single time (used for scan-resistance)
SINGLE - org.apache.accumulo.core.spi.scan.ScanInfo.Type
A single range scan started using a Scanner
SINGLE - org.apache.accumulo.core.tabletscan.thrift.ScanType
 
SINGLE_FACTOR_PROPERTY - Static variable in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
singleFactor(float) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
SingletonManager - Class in org.apache.accumulo.core.singletons
This class automates management of static singletons that maintain state for Accumulo clients.
SingletonManager() - Constructor for class org.apache.accumulo.core.singletons.SingletonManager
 
SingletonManager.Mode - Enum in org.apache.accumulo.core.singletons
These enums determine the behavior of the SingletonManager.
SingletonReservation - Class in org.apache.accumulo.core.singletons
 
SingletonReservation() - Constructor for class org.apache.accumulo.core.singletons.SingletonReservation
 
SingletonService - Interface in org.apache.accumulo.core.singletons
The SingletonManager uses this interface to enable and disable singleton services.
SITE - org.apache.accumulo.core.clientImpl.thrift.ConfigurationType
 
SiteConfiguration - Class in org.apache.accumulo.core.conf
An AccumuloConfiguration which first loads any properties set on the command-line (using the -o option) and then from accumulo.properties.
SiteConfiguration.Buildable - Interface in org.apache.accumulo.core.conf
 
SiteConfiguration.OverridesOption - Interface in org.apache.accumulo.core.conf
 
size - Variable in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
size() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
size() - Method in class org.apache.accumulo.core.data.Mutation
Gets the number of modifications / deletions in this mutation.
size() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCache
Get the size of this cache (number of cached blocks)
size() - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Get the size of the serialized Version object.
size() - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.Reader
 
size() - Method in class org.apache.accumulo.core.security.Authorizations
Gets the size of this collection of authorizations.
size() - Method in class org.apache.accumulo.core.util.MapCounter
 
size() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
 
Size(KeyExtent, long) - Constructor for class org.apache.accumulo.core.util.Merge.Size
 
SIZE - org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
 
SizeConstants - Class in org.apache.accumulo.core.file.blockfile.cache.impl
 
SizeConstants() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.impl.SizeConstants
 
SIZEOF_BOOLEAN - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.SizeConstants
 
SIZEOF_FLOAT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.SizeConstants
Size of float in bytes
SIZEOF_INT - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.SizeConstants
Size of int in bytes
SIZEOF_LONG - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.SizeConstants
Size of long in bytes
SkewedKeyValue() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection.SkewedKeyValue
 
skip(long) - Method in class org.apache.accumulo.core.crypto.streams.BlockedInputStream
 
skip(long) - Method in class org.apache.accumulo.core.file.blockfile.impl.SeekableByteArrayInputStream
 
skip(long) - Method in class org.apache.accumulo.core.file.streams.BoundedRangeFileInputStream
 
SKIP - org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeExistsPolicy
 
SKIP - org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeMissingPolicy
 
SkippingIterator - Class in org.apache.accumulo.core.iterators
Every call to SkippingIterator.next() and SkippingIterator.seek(Range, Collection, boolean) calls the parent's implementation and then calls the implementation's SkippingIterator.consume().
SkippingIterator() - Constructor for class org.apache.accumulo.core.iterators.SkippingIterator
 
sleep(long) - Method in class org.apache.accumulo.core.util.Retry
 
sleep(long) - Static method in class org.apache.accumulo.core.util.UtilWaitThread
 
Snappy - Class in org.apache.accumulo.core.spi.file.rfile.compression
 
Snappy() - Constructor for class org.apache.accumulo.core.spi.file.rfile.compression.Snappy
 
sortedColFams - Variable in class org.apache.accumulo.core.iteratorsImpl.system.ColumnFamilySkippingIterator
 
SortedKeyIterator - Class in org.apache.accumulo.core.iterators
 
SortedKeyIterator() - Constructor for class org.apache.accumulo.core.iterators.SortedKeyIterator
 
SortedKeyIterator(SortedKeyIterator, IteratorEnvironment) - Constructor for class org.apache.accumulo.core.iterators.SortedKeyIterator
 
SortedKeyValueIterator<K extends org.apache.hadoop.io.WritableComparable<?>,​V extends org.apache.hadoop.io.Writable> - Interface in org.apache.accumulo.core.iterators
An iterator that supports iterating over key and value pairs.
SortedMapIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
A simple iterator over a Java SortedMap Note that this class is intended as an in-memory replacement for RFile$Reader, so its behavior reflects the same assumptions; namely, that this iterator is not responsible for respecting the columnFamilies passed into seek().
SortedMapIterator(SortedMap<Key, Value>) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.SortedMapIterator
 
SortSkew - Class in org.apache.accumulo.core.metadata.schema
 
SortSkew() - Constructor for class org.apache.accumulo.core.metadata.schema.SortSkew
 
SORTSKEW_LENGTH - Static variable in class org.apache.accumulo.core.metadata.schema.SortSkew
 
source - Variable in class org.apache.accumulo.core.iterators.ServerWrappingIterator
 
source - Variable in class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
sourceIter - Variable in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
sources - Variable in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
sources - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
SOURCES - org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
SourceSwitchingIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
A SortedKeyValueIterator which presents a view over some section of data, regardless of whether or not it is backed by memory (InMemoryMap) or an RFile (InMemoryMap that was minor compacted to a file).
SourceSwitchingIterator(SourceSwitchingIterator.DataSource) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
SourceSwitchingIterator(SourceSwitchingIterator.DataSource, boolean) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
SourceSwitchingIterator.DataSource - Interface in org.apache.accumulo.core.iteratorsImpl.system
 
SpaceAwareVolumeChooser - Class in org.apache.accumulo.core.spi.fs
A PreferredVolumeChooser that takes remaining HDFS space into account when making a volume choice rather than a simpler round-robin.
SpaceAwareVolumeChooser() - Constructor for class org.apache.accumulo.core.spi.fs.SpaceAwareVolumeChooser
 
split - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
split(byte[]) - Static method in class org.apache.accumulo.core.clientImpl.lexicoder.ByteUtils
Splits a byte array by 0x00
split(byte[], int, int) - Static method in class org.apache.accumulo.core.clientImpl.lexicoder.ByteUtils
Splits a byte array by 0x00
split(String) - Method in class org.apache.accumulo.core.cli.ClientOpts.NullSplitter
 
split(String) - Method in class org.apache.accumulo.core.cli.ConfigOpts.NullSplitter
 
split(KeyExtent, KeyExtent, KeyExtent, TServerInstance) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
SPLIT - org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
 
SPLIT_CREATION_TIME - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
SPLIT_POINT - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args._Fields
 
SPLIT_RATIO - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
SPLIT_RATIO_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
 
SPLIT_RATIO_QUAL - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
A temporary field for splits to optimize certain operations
splitCreationTime - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
splitCurrentByRegex(SortedMap<TabletServerId, TServerStatus>) - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
Group the set of current tservers by pool name.
SplitLarge - Class in org.apache.accumulo.core.file.rfile
Split an RFile into large and small key/value files.
SplitLarge() - Constructor for class org.apache.accumulo.core.file.rfile.SplitLarge
 
splitPoint - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
splitRangeByTablets(String, Range, int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
 
splitRangeByTablets(String, Range, int) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
splits - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
SPLITS - org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
 
splitTablet() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.splitTablet
 
splitTablet() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.splitTablet
 
splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer) - Method in interface org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Iface
 
splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient
 
splitTablet(TInfo, TCredentials, TKeyExtent, ByteBuffer, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncIface
 
splitTablet_args() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
splitTablet_args(TInfo, TCredentials, TKeyExtent, ByteBuffer) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
splitTablet_args(TabletManagementClientService.splitTablet_args) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
Performs a deep copy on other.
splitTablet_call(TInfo, TCredentials, TKeyExtent, ByteBuffer, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.splitTablet_call
 
splitTablet_result() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
splitTablet_result(ThriftSecurityException, NotServingTabletException) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
splitTablet_result(TabletManagementClientService.splitTablet_result) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
Performs a deep copy on other.
ssbe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
ssbe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
ssbe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
ssbe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
SSBE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result._Fields
 
SSBE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
 
SSBE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result._Fields
 
SSBE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
 
SSERV_CACHED_TABLET_METADATA_EXPIRATION - org.apache.accumulo.core.conf.Property
 
SSERV_CLIENTPORT - org.apache.accumulo.core.conf.Property
 
SSERV_DATACACHE_SIZE - org.apache.accumulo.core.conf.Property
 
SSERV_DEFAULT_BLOCKSIZE - org.apache.accumulo.core.conf.Property
 
SSERV_GROUP_NAME - org.apache.accumulo.core.conf.Property
 
SSERV_INDEXCACHE_SIZE - org.apache.accumulo.core.conf.Property
 
SSERV_MAX_MESSAGE_SIZE - org.apache.accumulo.core.conf.Property
 
SSERV_MINTHREADS - org.apache.accumulo.core.conf.Property
 
SSERV_MINTHREADS_TIMEOUT - org.apache.accumulo.core.conf.Property
 
SSERV_PORTSEARCH - org.apache.accumulo.core.conf.Property
 
SSERV_PREFIX - org.apache.accumulo.core.conf.Property
 
SSERV_SCAN_EXECUTORS_DEFAULT_PRIORITIZER - org.apache.accumulo.core.conf.Property
 
SSERV_SCAN_EXECUTORS_DEFAULT_THREADS - org.apache.accumulo.core.conf.Property
 
SSERV_SCAN_EXECUTORS_META_THREADS - org.apache.accumulo.core.conf.Property
 
SSERV_SCAN_EXECUTORS_PREFIX - org.apache.accumulo.core.conf.Property
 
SSERV_SUMMARYCACHE_SIZE - org.apache.accumulo.core.conf.Property
 
SSERV_THREADCHECK - org.apache.accumulo.core.conf.Property
 
SSERVER_SCAN_REFERENCE_EXPIRATION_TIME - org.apache.accumulo.core.conf.Property
 
SSI_LIST - org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
SSI_LIST - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
 
SSI_LIST - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
SSI_LIST - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
ssiList - Variable in class org.apache.accumulo.core.clientImpl.CompressedIterators.IterConfig
 
ssiList - Variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
ssiList - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
ssiList - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
ssiList - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
ssio - Variable in class org.apache.accumulo.core.clientImpl.CompressedIterators.IterConfig
 
ssio - Variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
ssio - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
ssio - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
ssio - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
SSIO - org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
SSIO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
 
SSIO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
SSIO - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
SSL_ENABLED - org.apache.accumulo.core.conf.ClientProperty
 
SSL_KEYSTORE_PASSWORD - org.apache.accumulo.core.conf.ClientProperty
 
SSL_KEYSTORE_PATH - org.apache.accumulo.core.conf.ClientProperty
 
SSL_KEYSTORE_TYPE - org.apache.accumulo.core.conf.ClientProperty
 
SSL_TRUSTSTORE_PASSWORD - org.apache.accumulo.core.conf.ClientProperty
 
SSL_TRUSTSTORE_PATH - org.apache.accumulo.core.conf.ClientProperty
 
SSL_TRUSTSTORE_TYPE - org.apache.accumulo.core.conf.ClientProperty
 
SSL_USE_JSSE - org.apache.accumulo.core.conf.ClientProperty
 
SslConnectionParams - Class in org.apache.accumulo.core.rpc
 
StackOverflowException - Exception in org.apache.accumulo.core.fate
 
StackOverflowException(String) - Constructor for exception org.apache.accumulo.core.fate.StackOverflowException
 
start - Variable in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
start() - Method in class org.apache.accumulo.core.util.OpTimer
Start the timer instance.
start(I, ClientService.authenticate_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticate
 
start(I, ClientService.authenticateUser_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.authenticateUser
 
start(I, ClientService.changeAuthorizations_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeAuthorizations
 
start(I, ClientService.changeLocalUserPassword_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.changeLocalUserPassword
 
start(I, ClientService.checkClass_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkClass
 
start(I, ClientService.checkNamespaceClass_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkNamespaceClass
 
start(I, ClientService.checkTableClass_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.checkTableClass
 
start(I, ClientService.createLocalUser_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.createLocalUser
 
start(I, ClientService.dropLocalUser_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.dropLocalUser
 
start(I, ClientService.getConfiguration_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getConfiguration
 
start(I, ClientService.getDiskUsage_args, AsyncMethodCallback<List<TDiskUsage>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getDiskUsage
 
start(I, ClientService.getInstanceId_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getInstanceId
 
start(I, ClientService.getNamespaceConfiguration_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceConfiguration
 
start(I, ClientService.getNamespaceProperties_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getNamespaceProperties
 
start(I, ClientService.getRootTabletLocation_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getRootTabletLocation
 
start(I, ClientService.getSystemProperties_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getSystemProperties
 
start(I, ClientService.getTableConfiguration_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableConfiguration
 
start(I, ClientService.getTableProperties_args, AsyncMethodCallback<Map<String, String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getTableProperties
 
start(I, ClientService.getUserAuthorizations_args, AsyncMethodCallback<List<ByteBuffer>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getUserAuthorizations
 
start(I, ClientService.getVersionedNamespaceProperties_args, AsyncMethodCallback<TVersionedProperties>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedNamespaceProperties
 
start(I, ClientService.getVersionedSystemProperties_args, AsyncMethodCallback<TVersionedProperties>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedSystemProperties
 
start(I, ClientService.getVersionedTableProperties_args, AsyncMethodCallback<TVersionedProperties>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getVersionedTableProperties
 
start(I, ClientService.getZooKeepers_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.getZooKeepers
 
start(I, ClientService.grantNamespacePermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantNamespacePermission
 
start(I, ClientService.grantSystemPermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantSystemPermission
 
start(I, ClientService.grantTablePermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.grantTablePermission
 
start(I, ClientService.hasNamespacePermission_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasNamespacePermission
 
start(I, ClientService.hasSystemPermission_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasSystemPermission
 
start(I, ClientService.hasTablePermission_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.hasTablePermission
 
start(I, ClientService.isActive_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.isActive
 
start(I, ClientService.listLocalUsers_args, AsyncMethodCallback<Set<String>>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.listLocalUsers
 
start(I, ClientService.ping_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.ping
 
start(I, ClientService.revokeNamespacePermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeNamespacePermission
 
start(I, ClientService.revokeSystemPermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeSystemPermission
 
start(I, ClientService.revokeTablePermission_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncProcessor.revokeTablePermission
 
start(I, ThriftTest.fails_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.fails
 
start(I, ThriftTest.success_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.success
 
start(I, ThriftTest.throwsError_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.throwsError
 
start(I, CompactionCoordinatorService.cancel_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.cancel
 
start(I, CompactionCoordinatorService.compactionCompleted_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionCompleted
 
start(I, CompactionCoordinatorService.compactionFailed_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.compactionFailed
 
start(I, CompactionCoordinatorService.getCompactionJob_args, AsyncMethodCallback<TExternalCompactionJob>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompactionJob
 
start(I, CompactionCoordinatorService.getCompletedCompactions_args, AsyncMethodCallback<TExternalCompactionList>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getCompletedCompactions
 
start(I, CompactionCoordinatorService.getRunningCompactions_args, AsyncMethodCallback<TExternalCompactionList>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.getRunningCompactions
 
start(I, CompactionCoordinatorService.updateCompactionStatus_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.updateCompactionStatus
 
start(I, CompactorService.cancel_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.cancel
 
start(I, CompactorService.getActiveCompactions_args, AsyncMethodCallback<List<ActiveCompaction>>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getActiveCompactions
 
start(I, CompactorService.getRunningCompaction_args, AsyncMethodCallback<TExternalCompactionJob>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompaction
 
start(I, CompactorService.getRunningCompactionId_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncProcessor.getRunningCompactionId
 
start(I, GCMonitorService.getStatus_args, AsyncMethodCallback<GCStatus>) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncProcessor.getStatus
 
start(I, FateService.beginFateOperation_args, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.beginFateOperation
 
start(I, FateService.cancelFateOperation_args, AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.cancelFateOperation
 
start(I, FateService.executeFateOperation_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.executeFateOperation
 
start(I, FateService.finishFateOperation_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.finishFateOperation
 
start(I, FateService.waitForFateOperation_args, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.waitForFateOperation
 
start(I, ManagerClientService.getActiveTservers_args, AsyncMethodCallback<List<String>>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getActiveTservers
 
start(I, ManagerClientService.getDelegationToken_args, AsyncMethodCallback<TDelegationToken>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getDelegationToken
 
start(I, ManagerClientService.getManagerStats_args, AsyncMethodCallback<ManagerMonitorInfo>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.getManagerStats
 
start(I, ManagerClientService.initiateFlush_args, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.initiateFlush
 
start(I, ManagerClientService.modifyNamespaceProperties_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyNamespaceProperties
 
start(I, ManagerClientService.modifySystemProperties_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifySystemProperties
 
start(I, ManagerClientService.modifyTableProperties_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.modifyTableProperties
 
start(I, ManagerClientService.removeNamespaceProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeNamespaceProperty
 
start(I, ManagerClientService.removeSystemProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeSystemProperty
 
start(I, ManagerClientService.removeTableProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.removeTableProperty
 
start(I, ManagerClientService.reportSplitExtent_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportSplitExtent
 
start(I, ManagerClientService.reportTabletStatus_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.reportTabletStatus
 
start(I, ManagerClientService.setManagerGoalState_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setManagerGoalState
 
start(I, ManagerClientService.setNamespaceProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setNamespaceProperty
 
start(I, ManagerClientService.setSystemProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setSystemProperty
 
start(I, ManagerClientService.setTableProperty_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.setTableProperty
 
start(I, ManagerClientService.shutdown_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdown
 
start(I, ManagerClientService.shutdownTabletServer_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.shutdownTabletServer
 
start(I, ManagerClientService.waitForBalance_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForBalance
 
start(I, ManagerClientService.waitForFlush_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForFlush
 
start(I, TabletManagementClientService.chop_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.chop
 
start(I, TabletManagementClientService.flushTablet_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.flushTablet
 
start(I, TabletManagementClientService.loadTablet_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.loadTablet
 
start(I, TabletManagementClientService.splitTablet_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.splitTablet
 
start(I, TabletManagementClientService.unloadTablet_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.unloadTablet
 
start(I, TabletIngestClientService.applyUpdates_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.applyUpdates
 
start(I, TabletIngestClientService.closeConditionalUpdate_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.closeConditionalUpdate
 
start(I, TabletIngestClientService.closeUpdate_args, AsyncMethodCallback<UpdateErrors>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.closeUpdate
 
start(I, TabletIngestClientService.conditionalUpdate_args, AsyncMethodCallback<List<TCMResult>>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.conditionalUpdate
 
start(I, TabletIngestClientService.invalidateConditionalUpdate_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.invalidateConditionalUpdate
 
start(I, TabletIngestClientService.loadFiles_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.loadFiles
 
start(I, TabletIngestClientService.startConditionalUpdate_args, AsyncMethodCallback<TConditionalSession>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startConditionalUpdate
 
start(I, TabletIngestClientService.startUpdate_args, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startUpdate
 
start(I, TabletIngestClientService.update_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.update
 
start(I, TabletScanClientService.closeMultiScan_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.closeMultiScan
 
start(I, TabletScanClientService.closeScan_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.closeScan
 
start(I, TabletScanClientService.continueMultiScan_args, AsyncMethodCallback<MultiScanResult>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.continueMultiScan
 
start(I, TabletScanClientService.continueScan_args, AsyncMethodCallback<ScanResult>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.continueScan
 
start(I, TabletScanClientService.getActiveScans_args, AsyncMethodCallback<List<ActiveScan>>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.getActiveScans
 
start(I, TabletScanClientService.startMultiScan_args, AsyncMethodCallback<InitialMultiScan>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startMultiScan
 
start(I, TabletScanClientService.startScan_args, AsyncMethodCallback<InitialScan>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startScan
 
start(I, TabletServerClientService.compact_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compact
 
start(I, TabletServerClientService.compactionJobFailed_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compactionJobFailed
 
start(I, TabletServerClientService.compactionJobFinished_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.compactionJobFinished
 
start(I, TabletServerClientService.contiuneGetSummaries_args, AsyncMethodCallback<TSummaries>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.contiuneGetSummaries
 
start(I, TabletServerClientService.fastHalt_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.fastHalt
 
start(I, TabletServerClientService.flush_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.flush
 
start(I, TabletServerClientService.getActiveCompactions_args, AsyncMethodCallback<List<ActiveCompaction>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveCompactions
 
start(I, TabletServerClientService.getActiveLogs_args, AsyncMethodCallback<List<String>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getActiveLogs
 
start(I, TabletServerClientService.getCompactionQueueInfo_args, AsyncMethodCallback<List<TCompactionQueueSummary>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getCompactionQueueInfo
 
start(I, TabletServerClientService.getHistoricalStats_args, AsyncMethodCallback<TabletStats>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getHistoricalStats
 
start(I, TabletServerClientService.getTabletServerStatus_args, AsyncMethodCallback<TabletServerStatus>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletServerStatus
 
start(I, TabletServerClientService.getTabletStats_args, AsyncMethodCallback<List<TabletStats>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.getTabletStats
 
start(I, TabletServerClientService.halt_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.halt
 
start(I, TabletServerClientService.removeLogs_args, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.removeLogs
 
start(I, TabletServerClientService.reserveCompactionJob_args, AsyncMethodCallback<TExternalCompactionJob>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.reserveCompactionJob
 
start(I, TabletServerClientService.startGetSummaries_args, AsyncMethodCallback<TSummaries>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummaries
 
start(I, TabletServerClientService.startGetSummariesForPartition_args, AsyncMethodCallback<TSummaries>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesForPartition
 
start(I, TabletServerClientService.startGetSummariesFromFiles_args, AsyncMethodCallback<TSummaries>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesFromFiles
 
start(String[]) - Method in class org.apache.accumulo.core.util.Merge
 
start(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
start(BlockCacheManager.Configuration) - Method in class org.apache.accumulo.core.spi.cache.BlockCacheManager
Initialize the caches for each CacheType based on the configuration
START - org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
START - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
START_BOUND - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
START_INCL - Static variable in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
START_INCLUSIVE - Static variable in class org.apache.accumulo.core.iterators.user.ColumnSliceFilter
 
START_KEY_INCLUSIVE - org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
START_ROW - org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
 
START_ROW - org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
START_ROW - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args._Fields
 
START_ROW - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args._Fields
 
START_TIME - org.apache.accumulo.core.manager.thrift.BulkImportStatus._Fields
 
startBlock() - Method in interface org.apache.accumulo.core.file.rfile.MetricsGatherer
Start a new block within a LocalityGroup.
startBlock() - Method in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
startClientRpcSpan(Class<?>, String) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
startConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startConditionalUpdate
 
startConditionalUpdate() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startConditionalUpdate
 
startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String, TDurability, String) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String, TDurability, String) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Iface
 
startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String, TDurability, String, AsyncMethodCallback<TConditionalSession>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient
 
startConditionalUpdate(TInfo, TCredentials, List<ByteBuffer>, String, TDurability, String, AsyncMethodCallback<TConditionalSession>) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncIface
 
startConditionalUpdate_args() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
startConditionalUpdate_args(TInfo, TCredentials, List<ByteBuffer>, String, TDurability, String) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
startConditionalUpdate_args(TabletIngestClientService.startConditionalUpdate_args) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
Performs a deep copy on other.
startConditionalUpdate_call(TInfo, TCredentials, List<ByteBuffer>, String, TDurability, String, AsyncMethodCallback<TConditionalSession>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.startConditionalUpdate_call
 
startConditionalUpdate_result() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
startConditionalUpdate_result(TConditionalSession, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
startConditionalUpdate_result(TabletIngestClientService.startConditionalUpdate_result) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
Performs a deep copy on other.
startDefaultLocalityGroup() - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
A locality group in which the column families do not need to specified.
startDefaultLocalityGroup() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
startDefaultLocalityGroup() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
startDefaultLocalityGroup() - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
startDefaultLocalityGroup() - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
started - Variable in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
STARTED - org.apache.accumulo.core.compaction.thrift.TCompactionState
 
STARTED - org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
 
startFateSpan(Class<?>, String, TInfo) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
startGetSummaries() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummaries
 
startGetSummaries() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummaries
 
startGetSummaries(TInfo, TCredentials, TSummaryRequest) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
startGetSummaries(TInfo, TCredentials, TSummaryRequest) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
startGetSummaries(TInfo, TCredentials, TSummaryRequest, AsyncMethodCallback<TSummaries>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
startGetSummaries(TInfo, TCredentials, TSummaryRequest, AsyncMethodCallback<TSummaries>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
startGetSummaries_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
startGetSummaries_args(TInfo, TCredentials, TSummaryRequest) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
startGetSummaries_args(TabletServerClientService.startGetSummaries_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
Performs a deep copy on other.
startGetSummaries_call(TInfo, TCredentials, TSummaryRequest, AsyncMethodCallback<TSummaries>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummaries_call
 
startGetSummaries_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
startGetSummaries_result(TSummaries, ThriftSecurityException, ThriftTableOperationException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
startGetSummaries_result(TabletServerClientService.startGetSummaries_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
Performs a deep copy on other.
startGetSummariesForPartition() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesForPartition
 
startGetSummariesForPartition() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesForPartition
 
startGetSummariesForPartition(TInfo, TCredentials, TSummaryRequest, int, int) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
startGetSummariesForPartition(TInfo, TCredentials, TSummaryRequest, int, int) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
startGetSummariesForPartition(TInfo, TCredentials, TSummaryRequest, int, int, AsyncMethodCallback<TSummaries>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
startGetSummariesForPartition(TInfo, TCredentials, TSummaryRequest, int, int, AsyncMethodCallback<TSummaries>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
startGetSummariesForPartition_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
startGetSummariesForPartition_args(TInfo, TCredentials, TSummaryRequest, int, int) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
startGetSummariesForPartition_args(TabletServerClientService.startGetSummariesForPartition_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
Performs a deep copy on other.
startGetSummariesForPartition_call(TInfo, TCredentials, TSummaryRequest, int, int, AsyncMethodCallback<TSummaries>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummariesForPartition_call
 
startGetSummariesForPartition_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
startGetSummariesForPartition_result(TSummaries, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
startGetSummariesForPartition_result(TabletServerClientService.startGetSummariesForPartition_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
Performs a deep copy on other.
startGetSummariesFromFiles() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncProcessor.startGetSummariesFromFiles
 
startGetSummariesFromFiles() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Processor.startGetSummariesFromFiles
 
startGetSummariesFromFiles(TInfo, TCredentials, TSummaryRequest, Map<String, List<TRowRange>>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Client
 
startGetSummariesFromFiles(TInfo, TCredentials, TSummaryRequest, Map<String, List<TRowRange>>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.Iface
 
startGetSummariesFromFiles(TInfo, TCredentials, TSummaryRequest, Map<String, List<TRowRange>>, AsyncMethodCallback<TSummaries>) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient
 
startGetSummariesFromFiles(TInfo, TCredentials, TSummaryRequest, Map<String, List<TRowRange>>, AsyncMethodCallback<TSummaries>) - Method in interface org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncIface
 
startGetSummariesFromFiles_args() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
startGetSummariesFromFiles_args(TInfo, TCredentials, TSummaryRequest, Map<String, List<TRowRange>>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
startGetSummariesFromFiles_args(TabletServerClientService.startGetSummariesFromFiles_args) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
Performs a deep copy on other.
startGetSummariesFromFiles_call(TInfo, TCredentials, TSummaryRequest, Map<String, List<TRowRange>>, AsyncMethodCallback<TSummaries>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummariesFromFiles_call
 
startGetSummariesFromFiles_result() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
startGetSummariesFromFiles_result(TSummaries, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
startGetSummariesFromFiles_result(TabletServerClientService.startGetSummariesFromFiles_result) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
Performs a deep copy on other.
startKeyInclusive - Variable in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
startLocalityGroup(Text) - Method in interface org.apache.accumulo.core.file.rfile.MetricsGatherer
Start a new LocalityGroup.
startLocalityGroup(Text) - Method in class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
startMultiScan() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startMultiScan
 
startMultiScan() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startMultiScan
 
startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, TSamplerConfiguration, long, String, Map<String, String>, long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, TSamplerConfiguration, long, String, Map<String, String>, long) - Method in interface org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Iface
 
startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, TSamplerConfiguration, long, String, Map<String, String>, long, AsyncMethodCallback<InitialMultiScan>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient
 
startMultiScan(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, TSamplerConfiguration, long, String, Map<String, String>, long, AsyncMethodCallback<InitialMultiScan>) - Method in interface org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncIface
 
startMultiScan_args() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
startMultiScan_args(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, TSamplerConfiguration, long, String, Map<String, String>, long) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
startMultiScan_args(TabletScanClientService.startMultiScan_args) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
Performs a deep copy on other.
startMultiScan_call(TInfo, TCredentials, Map<TKeyExtent, List<TRange>>, List<TColumn>, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, TSamplerConfiguration, long, String, Map<String, String>, long, AsyncMethodCallback<InitialMultiScan>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.startMultiScan_call
 
startMultiScan_result() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
startMultiScan_result(InitialMultiScan, ThriftSecurityException, TSampleNotPresentException, ScanServerBusyException) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
startMultiScan_result(TabletScanClientService.startMultiScan_result) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
Performs a deep copy on other.
startNewLocalityGroup(String, byte[]...) - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
startNewLocalityGroup(String, String...) - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
startNewLocalityGroup(String, List<byte[]>) - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
Before appending any data, a locality group must be started.
startNewLocalityGroup(String, Set<String>) - Method in class org.apache.accumulo.core.client.rfile.RFileWriter
startNewLocalityGroup(String, Set<ByteSequence>) - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
startNewLocalityGroup(String, Set<ByteSequence>) - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
startNewLocalityGroup(String, Set<ByteSequence>) - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
startNewLocalityGroup(String, Set<ByteSequence>) - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
startRow - Variable in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
startRow - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
startRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
startRow - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
startRow(CharSequence) - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
The start row is not inclusive.
startRow(CharSequence) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryOptions
 
startRow(Text) - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
The start row is not inclusive.
startRow(Text) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryOptions
Summary data may possibly be stored at a more granular level than the entire file.
startScan() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncProcessor.startScan
 
startScan() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Processor.startScan
 
startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, TSamplerConfiguration, long, String, Map<String, String>, long) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Client
 
startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, TSamplerConfiguration, long, String, Map<String, String>, long) - Method in interface org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.Iface
 
startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, TSamplerConfiguration, long, String, Map<String, String>, long, AsyncMethodCallback<InitialScan>) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient
 
startScan(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, TSamplerConfiguration, long, String, Map<String, String>, long, AsyncMethodCallback<InitialScan>) - Method in interface org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncIface
 
startScan_args() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
startScan_args(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, TSamplerConfiguration, long, String, Map<String, String>, long) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
startScan_args(TabletScanClientService.startScan_args) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
Performs a deep copy on other.
startScan_call(TInfo, TCredentials, TKeyExtent, TRange, List<TColumn>, int, List<IterInfo>, Map<String, Map<String, String>>, List<ByteBuffer>, boolean, boolean, long, TSamplerConfiguration, long, String, Map<String, String>, long, AsyncMethodCallback<InitialScan>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.startScan_call
 
startScan_result() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
startScan_result(InitialScan, ThriftSecurityException, NotServingTabletException, TooManyFilesException, TSampleNotPresentException, ScanServerBusyException) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
startScan_result(TabletScanClientService.startScan_result) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
Performs a deep copy on other.
startServerRpcSpan(Class<?>, String, TInfo) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
startSpan(Class<?>, String) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
startSpan(Class<?>, String, Map<String, String>) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
startTime - Variable in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
startTransaction() - Method in class org.apache.accumulo.core.fate.Fate
 
startUpdate() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.startUpdate
 
startUpdate() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.startUpdate
 
startUpdate(TInfo, TCredentials, TDurability) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
startUpdate(TInfo, TCredentials, TDurability) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Iface
 
startUpdate(TInfo, TCredentials, TDurability, AsyncMethodCallback<Long>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient
 
startUpdate(TInfo, TCredentials, TDurability, AsyncMethodCallback<Long>) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncIface
 
startUpdate_args() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
startUpdate_args(TInfo, TCredentials, TDurability) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
startUpdate_args(TabletIngestClientService.startUpdate_args) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
Performs a deep copy on other.
startUpdate_call(TInfo, TCredentials, TDurability, AsyncMethodCallback<Long>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.startUpdate_call
 
startUpdate_result() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
startUpdate_result(long, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
startUpdate_result(TabletIngestClientService.startUpdate_result) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
Performs a deep copy on other.
Stat - Class in org.apache.accumulo.core.util
 
Stat() - Constructor for class org.apache.accumulo.core.util.Stat
 
state - Variable in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
state - Variable in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
state - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
state - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
state - Variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
STATE - org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
 
STATE - org.apache.accumulo.core.manager.thrift.BulkImportStatus._Fields
 
STATE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
 
STATE - org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
STATE - org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
StatisticsDisplayFormatter - Class in org.apache.accumulo.core.util.format
Does not show contents from scan, only displays statistics.
StatisticsDisplayFormatter() - Constructor for class org.apache.accumulo.core.util.format.StatisticsDisplayFormatter
 
stats - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
Stats - Interface in org.apache.accumulo.core.spi.common
 
STATS - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
StatsIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
 
StatsIterator(SortedKeyValueIterator<Key, Value>, AtomicLong, AtomicLong, LongAdder) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.StatsIterator
 
status - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
status - Variable in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
status - Variable in class org.apache.accumulo.core.manager.thrift.DeadServer
 
status - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
status - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
status - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
STATUS - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
STATUS - org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
 
STATUS - org.apache.accumulo.core.manager.thrift.DeadServer._Fields
 
STATUS - org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
STATUS - org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
STDIN - Static variable in class org.apache.accumulo.core.cli.ClientOpts.PasswordConverter
 
stop - Variable in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
stop() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheManager
 
stop() - Method in class org.apache.accumulo.core.spi.cache.BlockCacheManager
Stop caches and release resources
stop() - Method in class org.apache.accumulo.core.util.OpTimer
Stop the timer instance.
stop(K) - Method in class org.apache.accumulo.core.util.StopWatch
 
STOP - org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
STOP - org.apache.accumulo.core.manager.thrift.ManagerState
 
STOP_KEY_INCLUSIVE - org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
 
STOP_TABLET_SERVERS - org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
 
stopKeyInclusive - Variable in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
stopTabletServers - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
StopWatch<K extends Enum<K>> - Class in org.apache.accumulo.core.util
 
StopWatch(Class<K>) - Constructor for class org.apache.accumulo.core.util.StopWatch
 
StoredTabletFile - Class in org.apache.accumulo.core.metadata
Object representing a tablet file entry stored in the metadata table.
StoredTabletFile(String) - Constructor for class org.apache.accumulo.core.metadata.StoredTabletFile
Construct a tablet file using the string read from the metadata.
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.DeletesSection.SkewedKeyValue
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.BulkFileColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ChoppedColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ClonedColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.CurrentLocationColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.DataFileColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ExternalCompactionColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.FutureLocationColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LastLocationColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.LogColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ScanFileColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.SuspendLocationColumn
 
STR_NAME - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
This needs to sort after all other column families for that tablet, because the MetadataSchema.TabletsSection.TabletColumnFamily.PREV_ROW_COLUMN sits in this and that needs to sort last because the SimpleGarbageCollector relies on this.
stream() - Method in interface org.apache.accumulo.core.client.ScannerBase
Stream the Scanner results sequentially from this scanner's iterator
stream() - Method in class org.apache.accumulo.core.conf.AccumuloConfiguration
 
stream() - Method in class org.apache.accumulo.core.metadata.schema.TabletsMetadata
 
STRING - org.apache.accumulo.core.conf.PropertyType
 
STRING - org.apache.accumulo.core.iterators.LongCombiner.Type
indicates a string representation of a Long using LongCombiner.StringEncoder
STRING - org.apache.accumulo.core.iterators.user.SummingArrayCombiner.Type
indicates a string (comma-separated) representation of a list of Longs using SummingArrayCombiner.StringArrayEncoder
STRING - Static variable in class org.apache.accumulo.core.file.blockfile.cache.impl.ClassSize
String overhead
STRING_ARRAY_ENCODER - Static variable in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
STRING_ENCODER - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
StringArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.StringArrayEncoder
 
StringEncoder() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner.StringEncoder
 
stringify(ColumnVisibility.Node, byte[], StringBuilder) - Static method in class org.apache.accumulo.core.security.ColumnVisibility
 
StringLexicoder - Class in org.apache.accumulo.core.client.lexicoder
This lexicoder encodes/decodes a given String to/from bytes without further processing.
StringLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.StringLexicoder
 
stringTopKey(SortedKeyValueIterator<Key, Value>) - Static method in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
submitScannerReadAheadTask(Callable<List<KeyValue>>) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
SUBMITTED - org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Transaction that is eligible to be executed
subSequence(int, int) - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
subSequence(int, int) - Method in class org.apache.accumulo.core.data.ByteSequence
Returns a portion of this sequence.
SUCCEEDED - org.apache.accumulo.core.compaction.thrift.TCompactionState
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
success - Variable in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
success - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
success - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
success - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
success - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
success - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
success - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
success - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
success - Variable in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
success - Variable in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
success - Variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
success - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
success - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
success - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
success - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
success - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
success - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
success - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
success - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
success - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
success - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
success - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
success - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
success - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
success - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
success() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.success
 
success() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.success
 
success() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
success() - Method in interface org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Iface
 
success(AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient
 
success(AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncIface
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
 
SUCCESS - org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
 
SUCCESS - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result._Fields
 
SUCCESS - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result._Fields
 
SUCCESS - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result._Fields
 
SUCCESS - org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
 
SUCCESS - org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result._Fields
 
SUCCESS - org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result._Fields
 
SUCCESS - org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
 
SUCCESS - org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
 
SUCCESS - org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
 
SUCCESS - org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
 
SUCCESS - org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
 
SUCCESS - org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
 
SUCCESS - org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
 
SUCCESS - org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result._Fields
 
SUCCESS - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result._Fields
 
success_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
success_args(ThriftTest.success_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
Performs a deep copy on other.
success_call(AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.success_call
 
success_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
success_result(boolean) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
success_result(ThriftTest.success_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
Performs a deep copy on other.
SUCCESSFUL - org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Transaction has succeeded
sum() - Method in interface org.apache.accumulo.core.spi.common.Stats
 
sum() - Method in class org.apache.accumulo.core.util.Stat
 
SUM_DEV - org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
 
sumDev - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
summaries - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
summaries() - Static method in class org.apache.accumulo.core.client.rfile.RFile
Entry point for reading summary data from RFiles.
summaries(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Entry point for retrieving summaries with optional restrictions.
summaries(String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
SUMMARIES - org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
summarize(Summarizer.StatisticConsumer) - Method in interface org.apache.accumulo.core.client.summary.Summarizer.Collector
After Accumulo has written some Key Values, it will call this method to generate some statistics about what was previously passed to Summarizer.Collector.accept(Key, Value).
Summarizer - Interface in org.apache.accumulo.core.client.summary
Instances of this interface can be configured for Accumulo tables.
SUMMARIZER_PATTERN - org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
 
Summarizer.Collector - Interface in org.apache.accumulo.core.client.summary
When Accumulo calls methods in this interface, it will call Summarizer.Collector.accept(Key, Value) zero or more times and then call Summarizer.Collector.summarize(Summarizer.StatisticConsumer) once.
Summarizer.Combiner - Interface in org.apache.accumulo.core.client.summary
A Combiner is used to merge statistics emitted from Summarizer.Collector.summarize(Summarizer.StatisticConsumer) and from previous invocations of itself.
Summarizer.StatisticConsumer - Interface in org.apache.accumulo.core.client.summary
 
SummarizerConfiguration - Class in org.apache.accumulo.core.client.summary
This class encapsulates the configuration needed to instantiate a Summarizer.
SummarizerConfiguration.Builder - Class in org.apache.accumulo.core.client.summary
 
SummarizerConfigurationUtil - Class in org.apache.accumulo.core.summary
 
SummarizerConfigurationUtil() - Constructor for class org.apache.accumulo.core.summary.SummarizerConfigurationUtil
 
SummarizerFactory - Class in org.apache.accumulo.core.summary
 
SummarizerFactory() - Constructor for class org.apache.accumulo.core.summary.SummarizerFactory
 
SummarizerFactory(ClassLoader) - Constructor for class org.apache.accumulo.core.summary.SummarizerFactory
 
SummarizerFactory(AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.summary.SummarizerFactory
 
summarizerPattern - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
summarizers - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
SUMMARIZERS - org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
 
summary - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
Summary - Class in org.apache.accumulo.core.client.summary
This class encapsulates summary statistics, information about how those statistics were generated, and information about files the statistics were obtained from.
Summary(Map<String, Long>, SummarizerConfiguration, long, long, long, long, long) - Constructor for class org.apache.accumulo.core.client.summary.Summary
 
SUMMARY - org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
 
SUMMARY - org.apache.accumulo.core.spi.cache.CacheType
 
Summary.FileStatistics - Class in org.apache.accumulo.core.client.summary
 
SummaryCollection - Class in org.apache.accumulo.core.summary
This class facilitates merging, storing, and serializing (to/from thrift) intermediate summary information.
SummaryCollection() - Constructor for class org.apache.accumulo.core.summary.SummaryCollection
 
SummaryCollection(TSummaries) - Constructor for class org.apache.accumulo.core.summary.SummaryCollection
 
SummaryReader - Class in org.apache.accumulo.core.summary
 
SummaryReader() - Constructor for class org.apache.accumulo.core.summary.SummaryReader
 
SummaryRetriever - Interface in org.apache.accumulo.core.client.admin
This interface allows configuring where and which summary data to retrieve before retrieving it.
SummaryWriter - Class in org.apache.accumulo.core.summary
 
SummingArrayCombiner - Class in org.apache.accumulo.core.iterators.user
A Combiner that interprets Values as arrays of Longs and returns an array of element-wise sums.
SummingArrayCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
SummingArrayCombiner.DOSArrayEncoder<V> - Class in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.FixedLongArrayEncoder - Class in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.StringArrayEncoder - Class in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.Type - Enum in org.apache.accumulo.core.iterators.user
 
SummingArrayCombiner.VarLongArrayEncoder - Class in org.apache.accumulo.core.iterators.user
 
SummingCombiner - Class in org.apache.accumulo.core.iterators.user
A Combiner that interprets Values as Longs and returns their sum.
SummingCombiner() - Constructor for class org.apache.accumulo.core.iterators.user.SummingCombiner
 
supportsLocalityGroups() - Method in class org.apache.accumulo.core.file.BloomFilterLayer.Writer
 
supportsLocalityGroups() - Method in interface org.apache.accumulo.core.file.FileSKVWriter
 
supportsLocalityGroups() - Method in class org.apache.accumulo.core.file.rfile.RFile.Writer
 
supportsLocalityGroups() - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
SUPPRESS_ROW_VALUE - Static variable in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
suspend - Variable in class org.apache.accumulo.core.metadata.TabletLocationState
 
SUSPEND - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
SUSPEND_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.SuspendLocationColumn
 
suspended(KeyExtent, HostAndPort, long, TimeUnit, int) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
SUSPENDED - org.apache.accumulo.core.metadata.TabletState
 
SUSPENDED - org.apache.accumulo.core.tablet.thrift.TUnloadTabletGoal
 
SuspendingTServer - Class in org.apache.accumulo.core.metadata
For a suspended tablet, the time of suspension and the server it was suspended from.
SuspendLocationColumn() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.SuspendLocationColumn
 
suspensionTime - Variable in class org.apache.accumulo.core.metadata.SuspendingTServer
 
swap() - Method in class org.apache.accumulo.core.util.Pair
 
switchFile(String) - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
switchNow() - Method in class org.apache.accumulo.core.iteratorsImpl.system.SourceSwitchingIterator
 
symbols - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
SYMBOLS - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args._Fields
 
sync(String) - Method in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
SYNC - org.apache.accumulo.core.client.Durability
Write mutations to the write-ahead log, and ensure the data is saved to persistent storage.
SYNC - org.apache.accumulo.core.tabletingest.thrift.TDurability
 
SynchronizedIterator<K extends org.apache.hadoop.io.WritableComparable<?>,​V extends org.apache.hadoop.io.Writable> - Class in org.apache.accumulo.core.iteratorsImpl.system
Wraps a SortedKeyValueIterator so that all of its methods are synchronized.
SynchronizedIterator(SortedKeyValueIterator<K, V>) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.SynchronizedIterator
 
SynchronizedServerFilter - Class in org.apache.accumulo.core.iterators
A SortedKeyValueIterator similar to ServerFilter but with the implemented methods marked as synchronized.
SynchronizedServerFilter(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.SynchronizedServerFilter
 
SynchronousLoadingBlockCache - Class in org.apache.accumulo.core.file.blockfile.cache.lru
This class implements loading in such a way that load operations for the same block will not run concurrently.
SynchronousLoadingBlockCache() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.lru.SynchronousLoadingBlockCache
 
SyncingTabletLocator - Class in org.apache.accumulo.core.clientImpl
Syncs itself with the static collection of TabletLocators, so that when the server clears it, it will automatically get the most up-to-date version.
SyncingTabletLocator(Supplier<TabletLocator>) - Constructor for class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
SyncingTabletLocator(ClientContext, TableId) - Constructor for class org.apache.accumulo.core.clientImpl.SyncingTabletLocator
 
syncs - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
SYNCS - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
SYS_PERM - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
 
sysPerm - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
SYSTEM - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
Compaction initiated by system
SYSTEM - org.apache.accumulo.core.security.SystemPermission
 
SYSTEM - org.apache.accumulo.core.spi.compaction.CompactionKind
A system initiated routine compaction.
SYSTEM - org.apache.accumulo.core.tabletserver.thrift.TCompactionKind
 
SYSTEM - org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
 
SystemIteratorUtil - Class in org.apache.accumulo.core.iteratorsImpl.system
System utility class.
SystemIteratorUtil() - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.SystemIteratorUtil
 
systemNamespace() - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Returns the name of the system reserved namespace
systemNamespace() - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsHelper
 
SystemPermission - Enum in org.apache.accumulo.core.security
Accumulo system permissions.

T

T_SERVER_INFO - org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
table - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
TABLE - org.apache.accumulo.core.data.LoadPlan.RangeType
Range that corresponds to one or more tablets in a table.
TABLE - org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
 
TABLE - org.apache.accumulo.core.spi.crypto.CryptoEnvironment.Scope
 
TABLE - org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment.Scope
 
TABLE - org.apache.accumulo.core.spi.scan.ScanDispatch.CacheUsage
Use the tables cache settings for this scan.
TABLE_ARBITRARY_PROP_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_BLOCKCACHE_ENABLED - org.apache.accumulo.core.conf.Property
 
TABLE_BLOOM_ENABLED - org.apache.accumulo.core.conf.Property
 
TABLE_BLOOM_ERRORRATE - org.apache.accumulo.core.conf.Property
 
TABLE_BLOOM_HASHTYPE - org.apache.accumulo.core.conf.Property
 
TABLE_BLOOM_KEY_FUNCTOR - org.apache.accumulo.core.conf.Property
 
TABLE_BLOOM_LOAD_THRESHOLD - org.apache.accumulo.core.conf.Property
 
TABLE_BLOOM_SIZE - org.apache.accumulo.core.conf.Property
 
TABLE_BULK_IMPORT2 - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_BULK_MAX_TABLETS - org.apache.accumulo.core.conf.Property
 
TABLE_CANCEL_COMPACT - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_CLASSLOADER_CONTEXT - org.apache.accumulo.core.conf.Property
 
TABLE_CLONE - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_COMPACT - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_COMPACTION_CONFIGURER - org.apache.accumulo.core.conf.Property
 
TABLE_COMPACTION_CONFIGURER_OPTS - org.apache.accumulo.core.conf.Property
 
TABLE_COMPACTION_DISPATCHER - org.apache.accumulo.core.conf.Property
 
TABLE_COMPACTION_DISPATCHER_OPTS - org.apache.accumulo.core.conf.Property
 
TABLE_COMPACTION_SELECTION_EXPIRATION - org.apache.accumulo.core.conf.Property
 
TABLE_COMPACTION_SELECTOR - org.apache.accumulo.core.conf.Property
 
TABLE_COMPACTION_SELECTOR_OPTS - org.apache.accumulo.core.conf.Property
 
TABLE_CONSTRAINT_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_CREATE - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_CRYPTO_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_CRYPTO_SENSITIVE_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_DEFAULT_SCANTIME_VISIBILITY - org.apache.accumulo.core.conf.Property
 
TABLE_DELETE - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_DELETE_BEHAVIOR - org.apache.accumulo.core.conf.Property
 
TABLE_DELETE_RANGE - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_DELETED_MSG - Static variable in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
TABLE_DIR - Static variable in class org.apache.accumulo.core.Constants
 
TABLE_DOESNT_EXIST - org.apache.accumulo.core.client.security.SecurityErrorCode
 
TABLE_DOESNT_EXIST - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
TABLE_DURABILITY - org.apache.accumulo.core.conf.Property
 
TABLE_EXPORT - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_FAILURES_IGNORE - org.apache.accumulo.core.conf.Property
 
TABLE_FILE_BLOCK_SIZE - org.apache.accumulo.core.conf.Property
 
TABLE_FILE_COMPRESSED_BLOCK_SIZE - org.apache.accumulo.core.conf.Property
 
TABLE_FILE_COMPRESSED_BLOCK_SIZE_INDEX - org.apache.accumulo.core.conf.Property
 
TABLE_FILE_COMPRESSION_TYPE - org.apache.accumulo.core.conf.Property
 
TABLE_FILE_MAX - org.apache.accumulo.core.conf.Property
 
TABLE_FILE_REPLICATION - org.apache.accumulo.core.conf.Property
 
TABLE_FILE_SUMMARY_MAX_SIZE - org.apache.accumulo.core.conf.Property
 
TABLE_FILE_TYPE - org.apache.accumulo.core.conf.Property
 
TABLE_FORMATTER_CLASS - org.apache.accumulo.core.conf.Property
 
TABLE_ID - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
TABLE_ID - org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
TABLE_ID - org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
 
TABLE_ID - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args._Fields
 
TABLE_ID - org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
TABLE_ID - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args._Fields
 
TABLE_ID - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args._Fields
 
TABLE_ID - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args._Fields
 
TABLE_IMPORT - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_INDEXCACHE_ENABLED - org.apache.accumulo.core.conf.Property
 
TABLE_ITERATOR_MAJC_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_ITERATOR_MINC_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_ITERATOR_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_ITERATOR_SCAN_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_LOAD_BALANCER - org.apache.accumulo.core.conf.Property
 
TABLE_LOCALITY_GROUP_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_LOCALITY_GROUPS - org.apache.accumulo.core.conf.Property
 
TABLE_MAJC_OUTPUT_DROP_CACHE - org.apache.accumulo.core.conf.Property
 
TABLE_MAJC_RATIO - org.apache.accumulo.core.conf.Property
 
TABLE_MAP - org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
TABLE_MAP - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
TABLE_MAX_END_ROW_SIZE - org.apache.accumulo.core.conf.Property
 
TABLE_MERGE - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_MINC_COMPACT_IDLETIME - org.apache.accumulo.core.conf.Property
 
TABLE_MINC_OUTPUT_DROP_CACHE - org.apache.accumulo.core.conf.Property
 
TABLE_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
TABLE_NAME - org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
TABLE_NAME - org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
TABLE_OFFLINE - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_ONLINE - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_RENAME - org.apache.accumulo.core.manager.thrift.FateOperation
 
TABLE_SAMPLER - org.apache.accumulo.core.conf.Property
 
TABLE_SAMPLER_OPTS - org.apache.accumulo.core.conf.Property
 
TABLE_SCAN_DISPATCHER - org.apache.accumulo.core.conf.Property
 
TABLE_SCAN_DISPATCHER_OPTS - org.apache.accumulo.core.conf.Property
 
TABLE_SCAN_MAXMEM - org.apache.accumulo.core.conf.Property
 
TABLE_SERVICE_NAME_PROP - Static variable in class org.apache.accumulo.core.spi.crypto.GenericCryptoServiceFactory
 
TABLE_SERVICE_NAME_PROP - Static variable in class org.apache.accumulo.core.spi.crypto.PerTableCryptoServiceFactory
 
TABLE_SPLIT_THRESHOLD - org.apache.accumulo.core.conf.Property
 
TABLE_SUMMARIZER_PREFIX - org.apache.accumulo.core.conf.Property
 
TABLE_SUSPEND_DURATION - org.apache.accumulo.core.conf.Property
 
tableConfiguration - Variable in class org.apache.accumulo.core.file.FileOperations.FileOptions
 
tableConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
tableContext(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.classloader.ClassLoaderUtil
Retrieve the classloader context from a table's configuration.
tableContext(TableId) - Method in interface org.apache.accumulo.core.spi.balancer.BalancerEnvironment
Retrieve the classloader context that is configured for tableId, or null if none is configured.
TableDeletedException - Exception in org.apache.accumulo.core.client
This exception is thrown if a table is deleted after an operation starts.
TableDeletedException(String) - Constructor for exception org.apache.accumulo.core.client.TableDeletedException
 
TableDeletedException(String, Exception) - Constructor for exception org.apache.accumulo.core.client.TableDeletedException
 
TableExistsException - Exception in org.apache.accumulo.core.client
Thrown when the table specified already exists, and it was expected that it didn't
TableExistsException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.TableExistsException
 
TableExistsException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.TableExistsException
 
TableExistsException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.TableExistsException
 
tableId - Variable in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
tableId - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
tableId - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
tableId - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
tableId - Variable in class org.apache.accumulo.core.gc.ReferenceFile
 
tableId - Variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
tableId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
tableId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
tableId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
tableId - Variable in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
tableId() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Return the extent's table ID.
tableId() - Method in enum org.apache.accumulo.core.metadata.schema.Ample.DataLevel
 
tableID - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
TableId - Class in org.apache.accumulo.core.data
A strongly typed representation of a table ID.
tableIdMap() - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Get a mapping of table name to internal table id.
tableIdMap() - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
TableInfo - Class in org.apache.accumulo.core.manager.thrift
 
TableInfo() - Constructor for class org.apache.accumulo.core.manager.thrift.TableInfo
 
TableInfo(long, long, int, int, double, double, double, double, Compacting, Compacting, Compacting, double) - Constructor for class org.apache.accumulo.core.manager.thrift.TableInfo
 
TableInfo(TableInfo) - Constructor for class org.apache.accumulo.core.manager.thrift.TableInfo
Performs a deep copy on other.
TableInfo._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TableLoadBalancer - Class in org.apache.accumulo.core.spi.balancer
 
TableLoadBalancer() - Constructor for class org.apache.accumulo.core.spi.balancer.TableLoadBalancer
 
tableMap - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
tableMap - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
TableMap - Class in org.apache.accumulo.core.util.tables
Used for thread safe caching of immutable table ID maps.
TableMap(ClientContext) - Constructor for class org.apache.accumulo.core.util.tables.TableMap
 
tableName - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
tableName - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
tableName - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
tableName - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
tableName - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
tableName - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
tableName - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
tableName - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
tableName - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
tableName - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
tableName - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
tableName - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
TableNameUtil - Class in org.apache.accumulo.core.util.tables
 
tableNodeExists(TableId) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
tableNodeExists(TableId) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
 
TableNotFoundException - Exception in org.apache.accumulo.core.client
Thrown when the table specified doesn't exist when it was expected to
TableNotFoundException(String, String, String) - Constructor for exception org.apache.accumulo.core.client.TableNotFoundException
 
TableNotFoundException(String, String, String, Throwable) - Constructor for exception org.apache.accumulo.core.client.TableNotFoundException
 
TableNotFoundException(String, NamespaceNotFoundException) - Constructor for exception org.apache.accumulo.core.client.TableNotFoundException
 
TableNotFoundException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.client.TableNotFoundException
 
TableOfflineException - Exception in org.apache.accumulo.core.client
 
TableOfflineException(Exception) - Constructor for exception org.apache.accumulo.core.client.TableOfflineException
 
TableOfflineException(String) - Constructor for exception org.apache.accumulo.core.client.TableOfflineException
 
TableOfflineException(TableId, String) - Constructor for exception org.apache.accumulo.core.client.TableOfflineException
 
TableOperation - Enum in org.apache.accumulo.core.clientImpl.thrift
 
TableOperationExceptionType - Enum in org.apache.accumulo.core.clientImpl.thrift
 
tableOperations() - Method in interface org.apache.accumulo.core.client.AccumuloClient
Retrieves a TableOperations object to perform table functions, such as create and delete.
tableOperations() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
TableOperations - Interface in org.apache.accumulo.core.client.admin
Provides a class for administering tables
TableOperations.ImportDestinationArguments - Interface in org.apache.accumulo.core.client.admin
 
TableOperations.ImportMappingOptions - Interface in org.apache.accumulo.core.client.admin
Options giving control of how the bulk import file mapping is done.
TableOperations.ImportOptions - Interface in org.apache.accumulo.core.client.admin
 
TableOperationsHelper - Class in org.apache.accumulo.core.clientImpl
 
TableOperationsHelper() - Constructor for class org.apache.accumulo.core.clientImpl.TableOperationsHelper
 
TableOperationsImpl - Class in org.apache.accumulo.core.clientImpl
 
TableOperationsImpl(ClientContext) - Constructor for class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
TablePermission - Enum in org.apache.accumulo.core.security
Accumulo table permissions.
tables - Variable in class org.apache.accumulo.core.client.admin.DiskUsage
 
tables - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
tables - Variable in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
TABLES - org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
 
TABLES - org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
 
TableState - Enum in org.apache.accumulo.core.manager.state.tables
 
TableStatistics - Interface in org.apache.accumulo.core.spi.balancer.data
 
TableStatisticsImpl - Class in org.apache.accumulo.core.manager.balancer
 
TableStatisticsImpl(TableStatisticsImpl) - Constructor for class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
TableStatisticsImpl(TableInfo) - Constructor for class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
tablet - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
Tablet(Text, Text) - Constructor for class org.apache.accumulo.core.clientImpl.bulk.Bulk.Tablet
 
TABLET - org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
TABLET_INGEST - org.apache.accumulo.core.lock.ServiceLockData.ThriftService
 
TABLET_INGEST - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
TABLET_MANAGEMENT - org.apache.accumulo.core.lock.ServiceLockData.ThriftService
 
TABLET_MGMT - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
TABLET_SCAN - org.apache.accumulo.core.lock.ServiceLockData.ThriftService
 
TABLET_SCAN - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
TABLET_SERVER - org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
 
TABLET_SERVER - Static variable in class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
TabletBalancer - Interface in org.apache.accumulo.core.spi.balancer
This class is responsible for managing the distribution of tablets throughout an Accumulo cluster.
TabletBalancer.AssignmentParameters - Interface in org.apache.accumulo.core.spi.balancer
An interface for grouping parameters required for the balancer to assign unassigned tablets.
TabletBalancer.BalanceParameters - Interface in org.apache.accumulo.core.spi.balancer
An interface for grouping parameters required for the balancer to balance tablets.
TabletColumnFamily() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.TabletColumnFamily
 
TabletDeletedException - Exception in org.apache.accumulo.core.metadata.schema
 
TabletDeletedException(String) - Constructor for exception org.apache.accumulo.core.metadata.schema.TabletDeletedException
 
TabletFile - Interface in org.apache.accumulo.core.metadata
An interface that represents different types of file references that are handled by code that processes tablet files.
TabletId - Interface in org.apache.accumulo.core.data
A TabletId provides the information needed to uniquely identify a tablet.
TabletIdImpl - Class in org.apache.accumulo.core.dataImpl
 
TabletIdImpl(KeyExtent) - Constructor for class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
tableTime(boolean) - Method in interface org.apache.accumulo.core.client.admin.TableOperations.ImportOptions
Use table's next timestamp to override all timestamps in imported files.
tableTime(boolean) - Method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
TabletIngestClientService - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService
 
TabletIngestClientService.applyUpdates_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.applyUpdates_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.AsyncClient - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.applyUpdates_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.closeConditionalUpdate_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.closeUpdate_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.conditionalUpdate_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.invalidateConditionalUpdate_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.loadFiles_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.startConditionalUpdate_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.startUpdate_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncClient.update_call - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncIface - Interface in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.applyUpdates<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.closeConditionalUpdate<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.closeUpdate<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.conditionalUpdate<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.invalidateConditionalUpdate<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.loadFiles<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.startConditionalUpdate<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.startUpdate<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.AsyncProcessor.update<I extends TabletIngestClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Client - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Client.Factory - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.closeConditionalUpdate_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.closeConditionalUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.closeUpdate_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.closeUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.closeUpdate_result - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.closeUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.conditionalUpdate_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.conditionalUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.conditionalUpdate_result - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.conditionalUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.Iface - Interface in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.invalidateConditionalUpdate_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.invalidateConditionalUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.invalidateConditionalUpdate_result - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.invalidateConditionalUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.loadFiles_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.loadFiles_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.Processor<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.applyUpdates<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.closeConditionalUpdate<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.closeUpdate<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.conditionalUpdate<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.invalidateConditionalUpdate<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.loadFiles<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.startConditionalUpdate<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.startUpdate<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.Processor.update<I extends TabletIngestClientService.Iface> - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.startConditionalUpdate_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.startConditionalUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.startConditionalUpdate_result - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.startConditionalUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.startUpdate_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.startUpdate_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.startUpdate_result - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.startUpdate_result._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.update_args - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.update_args._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientService.update_result - Class in org.apache.accumulo.core.tabletingest.thrift
 
TabletIngestClientService.update_result._Fields - Enum in org.apache.accumulo.core.tabletingest.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletIngestClientServiceThriftClient - Class in org.apache.accumulo.core.rpc.clients
Client side object that can be used to interact with services that support ingest operations against tablets.
TabletIngestClientServiceThriftClient(String) - Constructor for class org.apache.accumulo.core.rpc.clients.TabletIngestClientServiceThriftClient
 
TabletLoadState - Enum in org.apache.accumulo.core.manager.thrift
 
TabletLocation(KeyExtent, String, String) - Constructor for class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocation
 
TabletLocations(List<TabletLocator.TabletLocation>, List<KeyExtent>) - Constructor for class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocations
 
TabletLocationState - Class in org.apache.accumulo.core.metadata
When a tablet is assigned, we mark its future location.
TabletLocationState(KeyExtent, TabletMetadata.Location, TabletMetadata.Location, TabletMetadata.Location, SuspendingTServer, Collection<Collection<String>>, boolean) - Constructor for class org.apache.accumulo.core.metadata.TabletLocationState
 
TabletLocationState.BadLocationStateException - Exception in org.apache.accumulo.core.metadata
 
TabletLocator - Class in org.apache.accumulo.core.clientImpl
 
TabletLocator() - Constructor for class org.apache.accumulo.core.clientImpl.TabletLocator
 
TabletLocator.TabletLocation - Class in org.apache.accumulo.core.clientImpl
 
TabletLocator.TabletLocations - Class in org.apache.accumulo.core.clientImpl
 
TabletLocator.TabletServerMutations<T extends Mutation> - Class in org.apache.accumulo.core.clientImpl
 
TabletLocatorImpl - Class in org.apache.accumulo.core.clientImpl
 
TabletLocatorImpl(TableId, TabletLocator, TabletLocatorImpl.TabletLocationObtainer, TabletLocatorImpl.TabletServerLockChecker) - Constructor for class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
TabletLocatorImpl.TabletLocationObtainer - Interface in org.apache.accumulo.core.clientImpl
 
TabletLocatorImpl.TabletServerLockChecker - Interface in org.apache.accumulo.core.clientImpl
 
TabletLogger - Class in org.apache.accumulo.core.logging
This class contains source for logs messages about a tablets internal state, like its location, set of files, metadata.
TabletLogger() - Constructor for class org.apache.accumulo.core.logging.TabletLogger
 
TabletManagementClientService - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService
 
TabletManagementClientService.AsyncClient - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncClient.chop_call - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncClient.flushTablet_call - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncClient.loadTablet_call - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncClient.splitTablet_call - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncClient.unloadTablet_call - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncIface - Interface in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncProcessor<I extends TabletManagementClientService.AsyncIface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncProcessor.chop<I extends TabletManagementClientService.AsyncIface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncProcessor.flushTablet<I extends TabletManagementClientService.AsyncIface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncProcessor.loadTablet<I extends TabletManagementClientService.AsyncIface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncProcessor.splitTablet<I extends TabletManagementClientService.AsyncIface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.AsyncProcessor.unloadTablet<I extends TabletManagementClientService.AsyncIface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.chop_args - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.chop_args._Fields - Enum in org.apache.accumulo.core.tablet.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletManagementClientService.Client - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.Client.Factory - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.flushTablet_args - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.flushTablet_args._Fields - Enum in org.apache.accumulo.core.tablet.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletManagementClientService.Iface - Interface in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.loadTablet_args - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.loadTablet_args._Fields - Enum in org.apache.accumulo.core.tablet.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletManagementClientService.Processor<I extends TabletManagementClientService.Iface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.Processor.chop<I extends TabletManagementClientService.Iface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.Processor.flushTablet<I extends TabletManagementClientService.Iface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.Processor.loadTablet<I extends TabletManagementClientService.Iface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.Processor.splitTablet<I extends TabletManagementClientService.Iface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.Processor.unloadTablet<I extends TabletManagementClientService.Iface> - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.splitTablet_args - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.splitTablet_args._Fields - Enum in org.apache.accumulo.core.tablet.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletManagementClientService.splitTablet_result - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.splitTablet_result._Fields - Enum in org.apache.accumulo.core.tablet.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletManagementClientService.unloadTablet_args - Class in org.apache.accumulo.core.tablet.thrift
 
TabletManagementClientService.unloadTablet_args._Fields - Enum in org.apache.accumulo.core.tablet.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletManagementClientServiceThriftClient - Class in org.apache.accumulo.core.rpc.clients
Client side object that can be used to interact with services that support management operations against tablets.
TabletManagementClientServiceThriftClient(String) - Constructor for class org.apache.accumulo.core.rpc.clients.TabletManagementClientServiceThriftClient
 
TabletMetadata - Class in org.apache.accumulo.core.metadata.schema
 
TabletMetadata() - Constructor for class org.apache.accumulo.core.metadata.schema.TabletMetadata
 
TabletMetadata.ColumnType - Enum in org.apache.accumulo.core.metadata.schema
 
TabletMetadata.Location - Class in org.apache.accumulo.core.metadata.schema
 
TabletMetadata.LocationType - Enum in org.apache.accumulo.core.metadata.schema
 
TabletMigration - Class in org.apache.accumulo.core.spi.balancer.data
 
TabletMigration(TabletId, TabletServerId, TabletServerId) - Constructor for class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
tablets - Variable in class org.apache.accumulo.core.manager.thrift.TableInfo
 
TABLETS - org.apache.accumulo.core.manager.thrift.TableInfo._Fields
 
TabletScanClientService - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService
 
TabletScanClientService.AsyncClient - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncClient.closeMultiScan_call - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncClient.closeScan_call - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncClient.continueMultiScan_call - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncClient.continueScan_call - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncClient.getActiveScans_call - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncClient.startMultiScan_call - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncClient.startScan_call - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncIface - Interface in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncProcessor<I extends TabletScanClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncProcessor.closeMultiScan<I extends TabletScanClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncProcessor.closeScan<I extends TabletScanClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncProcessor.continueMultiScan<I extends TabletScanClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncProcessor.continueScan<I extends TabletScanClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncProcessor.getActiveScans<I extends TabletScanClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncProcessor.startMultiScan<I extends TabletScanClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.AsyncProcessor.startScan<I extends TabletScanClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Client - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Client.Factory - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.closeMultiScan_args - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.closeMultiScan_args._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.closeMultiScan_result - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.closeMultiScan_result._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.closeScan_args - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.closeScan_args._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.continueMultiScan_args - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.continueMultiScan_args._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.continueMultiScan_result - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.continueMultiScan_result._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.continueScan_args - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.continueScan_args._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.continueScan_result - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.continueScan_result._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.getActiveScans_args - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.getActiveScans_args._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.getActiveScans_result - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.getActiveScans_result._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.Iface - Interface in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Processor<I extends TabletScanClientService.Iface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Processor.closeMultiScan<I extends TabletScanClientService.Iface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Processor.closeScan<I extends TabletScanClientService.Iface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Processor.continueMultiScan<I extends TabletScanClientService.Iface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Processor.continueScan<I extends TabletScanClientService.Iface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Processor.getActiveScans<I extends TabletScanClientService.Iface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Processor.startMultiScan<I extends TabletScanClientService.Iface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.Processor.startScan<I extends TabletScanClientService.Iface> - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.startMultiScan_args - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.startMultiScan_args._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.startMultiScan_result - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.startMultiScan_result._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.startScan_args - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.startScan_args._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientService.startScan_result - Class in org.apache.accumulo.core.tabletscan.thrift
 
TabletScanClientService.startScan_result._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletScanClientServiceThriftClient - Class in org.apache.accumulo.core.rpc.clients
Client side object that can be used to interact with services that support scan operations against tablets.
tabletServer - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
TabletServerBatchDeleter - Class in org.apache.accumulo.core.clientImpl
 
TabletServerBatchDeleter(ClientContext, TableId, String, Authorizations, int, BatchWriterConfig) - Constructor for class org.apache.accumulo.core.clientImpl.TabletServerBatchDeleter
 
TabletServerBatchReader - Class in org.apache.accumulo.core.clientImpl
 
TabletServerBatchReader(ClientContext, Class<?>, TableId, String, Authorizations, int) - Constructor for class org.apache.accumulo.core.clientImpl.TabletServerBatchReader
 
TabletServerBatchReader(ClientContext, TableId, String, Authorizations, int) - Constructor for class org.apache.accumulo.core.clientImpl.TabletServerBatchReader
 
TabletServerBatchReaderIterator - Class in org.apache.accumulo.core.clientImpl
 
TabletServerBatchReaderIterator(ClientContext, TableId, String, Authorizations, ArrayList<Range>, int, ExecutorService, ScannerOptions, long) - Constructor for class org.apache.accumulo.core.clientImpl.TabletServerBatchReaderIterator
 
TabletServerBatchReaderIterator.ResultReceiver - Interface in org.apache.accumulo.core.clientImpl
 
TabletServerBatchWriter - Class in org.apache.accumulo.core.clientImpl
 
TabletServerBatchWriter(ClientContext, BatchWriterConfig) - Constructor for class org.apache.accumulo.core.clientImpl.TabletServerBatchWriter
 
TabletServerClientService - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService
 
TabletServerClientService.AsyncClient - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.compact_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.compactionJobFailed_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.compactionJobFinished_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.contiuneGetSummaries_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.Factory - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.fastHalt_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.flush_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.getActiveCompactions_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.getActiveLogs_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.getCompactionQueueInfo_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.getHistoricalStats_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.getTabletServerStatus_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.getTabletStats_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.halt_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.removeLogs_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.reserveCompactionJob_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.startGetSummaries_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.startGetSummariesForPartition_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncClient.startGetSummariesFromFiles_call - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncIface - Interface in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.compact<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.compactionJobFailed<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.compactionJobFinished<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.contiuneGetSummaries<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.fastHalt<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.flush<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.getActiveCompactions<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.getActiveLogs<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.getCompactionQueueInfo<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.getHistoricalStats<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.getTabletServerStatus<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.getTabletStats<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.halt<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.removeLogs<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.reserveCompactionJob<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.startGetSummaries<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.startGetSummariesForPartition<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.AsyncProcessor.startGetSummariesFromFiles<I extends TabletServerClientService.AsyncIface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Client - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Client.Factory - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.compact_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.compact_args._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.
TabletServerClientService.compactionJobFailed_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.compactionJobFailed_args._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.
TabletServerClientService.compactionJobFinished_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.compactionJobFinished_args._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.
TabletServerClientService.contiuneGetSummaries_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.contiuneGetSummaries_args._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.
TabletServerClientService.contiuneGetSummaries_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.contiuneGetSummaries_result._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.
TabletServerClientService.fastHalt_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.fastHalt_args._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.
TabletServerClientService.flush_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.flush_args._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.
TabletServerClientService.getActiveCompactions_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getActiveCompactions_args._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.
TabletServerClientService.getActiveCompactions_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getActiveCompactions_result._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.
TabletServerClientService.getActiveLogs_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getActiveLogs_args._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.
TabletServerClientService.getActiveLogs_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getActiveLogs_result._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.
TabletServerClientService.getCompactionQueueInfo_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getCompactionQueueInfo_args._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.
TabletServerClientService.getCompactionQueueInfo_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getCompactionQueueInfo_result._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.
TabletServerClientService.getHistoricalStats_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getHistoricalStats_args._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.
TabletServerClientService.getHistoricalStats_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getHistoricalStats_result._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.
TabletServerClientService.getTabletServerStatus_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getTabletServerStatus_args._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.
TabletServerClientService.getTabletServerStatus_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getTabletServerStatus_result._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.
TabletServerClientService.getTabletStats_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getTabletStats_args._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.
TabletServerClientService.getTabletStats_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.getTabletStats_result._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.
TabletServerClientService.halt_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.halt_args._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.
TabletServerClientService.halt_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.halt_result._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.
TabletServerClientService.Iface - Interface in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.compact<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.compactionJobFailed<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.compactionJobFinished<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.contiuneGetSummaries<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.fastHalt<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.flush<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.getActiveCompactions<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.getActiveLogs<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.getCompactionQueueInfo<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.getHistoricalStats<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.getTabletServerStatus<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.getTabletStats<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.halt<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.removeLogs<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.reserveCompactionJob<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.startGetSummaries<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.startGetSummariesForPartition<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.Processor.startGetSummariesFromFiles<I extends TabletServerClientService.Iface> - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.removeLogs_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.removeLogs_args._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.
TabletServerClientService.reserveCompactionJob_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.reserveCompactionJob_args._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.
TabletServerClientService.reserveCompactionJob_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.reserveCompactionJob_result._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.
TabletServerClientService.startGetSummaries_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.startGetSummaries_args._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.
TabletServerClientService.startGetSummaries_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.startGetSummaries_result._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.
TabletServerClientService.startGetSummariesForPartition_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.startGetSummariesForPartition_args._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.
TabletServerClientService.startGetSummariesForPartition_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.startGetSummariesForPartition_result._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.
TabletServerClientService.startGetSummariesFromFiles_args - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.startGetSummariesFromFiles_args._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.
TabletServerClientService.startGetSummariesFromFiles_result - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletServerClientService.startGetSummariesFromFiles_result._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.
TabletServerId - Interface in org.apache.accumulo.core.spi.balancer.data
 
TabletServerIdImpl - Class in org.apache.accumulo.core.manager.balancer
 
TabletServerIdImpl(String, int, String) - Constructor for class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
TabletServerIdImpl(TServerInstance) - Constructor for class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
TabletServerMutations(String) - Constructor for class org.apache.accumulo.core.clientImpl.TabletLocator.TabletServerMutations
 
TabletServerStatus - Class in org.apache.accumulo.core.manager.thrift
 
TabletServerStatus() - Constructor for class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
TabletServerStatus(Map<String, TableInfo>, long, String, double, long, long, long, long, long, long, List<RecoveryStatus>, long, long, List<BulkImportStatus>, String, long) - Constructor for class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
TabletServerStatus(TabletServerStatus) - Constructor for class org.apache.accumulo.core.manager.thrift.TabletServerStatus
Performs a deep copy on other.
TabletServerStatus._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletServerThriftClient - Class in org.apache.accumulo.core.rpc.clients
Client side object that can be used to interact with services that support operations against TabletServers.
TabletsMetadata - Class in org.apache.accumulo.core.metadata.schema
An abstraction layer for reading tablet metadata from the accumulo.metadata and accumulo.root tables.
TabletsMetadata.Builder - Class in org.apache.accumulo.core.metadata.schema
 
TabletsMetadata.Options - Interface in org.apache.accumulo.core.metadata.schema
 
TabletsMetadata.RangeOptions - Interface in org.apache.accumulo.core.metadata.schema
 
TabletsMetadata.TableOptions - Interface in org.apache.accumulo.core.metadata.schema
 
TabletsMetadata.TableRangeOptions - Interface in org.apache.accumulo.core.metadata.schema
 
TabletSplit - Class in org.apache.accumulo.core.manager.thrift
 
TabletSplit() - Constructor for class org.apache.accumulo.core.manager.thrift.TabletSplit
 
TabletSplit(TKeyExtent, List<TKeyExtent>) - Constructor for class org.apache.accumulo.core.manager.thrift.TabletSplit
 
TabletSplit(TabletSplit) - Constructor for class org.apache.accumulo.core.manager.thrift.TabletSplit
Performs a deep copy on other.
TabletSplit._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TabletsSection() - Constructor for class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection
 
TabletState - Enum in org.apache.accumulo.core.metadata
 
TabletStatistics - Interface in org.apache.accumulo.core.spi.balancer.data
 
TabletStatisticsImpl - Class in org.apache.accumulo.core.manager.balancer
 
TabletStatisticsImpl(TabletStats) - Constructor for class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
TabletStats - Class in org.apache.accumulo.core.tabletserver.thrift
 
TabletStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
TabletStats(TKeyExtent, ActionStats, ActionStats, ActionStats, long, double, double, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
TabletStats(TabletStats) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TabletStats
Performs a deep copy on other.
TabletStats._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.
TabletType - Enum in org.apache.accumulo.core.clientImpl
 
TableZooHelper - Class in org.apache.accumulo.core.util.tables
 
TableZooHelper(ClientContext) - Constructor for class org.apache.accumulo.core.util.tables.TableZooHelper
 
TAuthenticationKey - Class in org.apache.accumulo.core.securityImpl.thrift
 
TAuthenticationKey() - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
TAuthenticationKey(ByteBuffer) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
TAuthenticationKey(TAuthenticationKey) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
Performs a deep copy on other.
TAuthenticationKey._Fields - Enum in org.apache.accumulo.core.securityImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TAuthenticationTokenIdentifier - Class in org.apache.accumulo.core.securityImpl.thrift
 
TAuthenticationTokenIdentifier() - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
TAuthenticationTokenIdentifier(String) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
TAuthenticationTokenIdentifier(TAuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
Performs a deep copy on other.
TAuthenticationTokenIdentifier._Fields - Enum in org.apache.accumulo.core.securityImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TBL_NSPC_PERM - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
TBL_PERM - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
tblNspcPerm - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
tblPerm - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
TBufferedSocket - Class in org.apache.accumulo.core.rpc
 
TBufferedSocket(TSocket, int) - Constructor for class org.apache.accumulo.core.rpc.TBufferedSocket
 
tcme - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
tcme - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
tcme - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
TCME - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
 
TCME - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
 
TCME - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
TCMResult - Class in org.apache.accumulo.core.dataImpl.thrift
 
TCMResult() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
TCMResult(long, TCMStatus) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
TCMResult(TCMResult) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TCMResult
Performs a deep copy on other.
TCMResult._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCMStatus - Enum in org.apache.accumulo.core.dataImpl.thrift
 
TColumn - Class in org.apache.accumulo.core.dataImpl.thrift
 
TColumn() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
TColumn(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
TColumn(TColumn) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TColumn
Performs a deep copy on other.
TColumn._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCompactionKind - Enum in org.apache.accumulo.core.tabletserver.thrift
 
TCompactionQueueSummary - Class in org.apache.accumulo.core.tabletserver.thrift
 
TCompactionQueueSummary() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
TCompactionQueueSummary(String, short) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
TCompactionQueueSummary(TCompactionQueueSummary) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
Performs a deep copy on other.
TCompactionQueueSummary._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.
TCompactionReason - Enum in org.apache.accumulo.core.tabletserver.thrift
 
TCompactionState - Enum in org.apache.accumulo.core.compaction.thrift
 
TCompactionStats - Class in org.apache.accumulo.core.tabletserver.thrift
 
TCompactionStats() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
TCompactionStats(long, long, long) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
TCompactionStats(TCompactionStats) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
Performs a deep copy on other.
TCompactionStats._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.
TCompactionStatusUpdate - Class in org.apache.accumulo.core.compaction.thrift
 
TCompactionStatusUpdate() - Constructor for class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
TCompactionStatusUpdate(TCompactionState, String, long, long, long) - Constructor for class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
TCompactionStatusUpdate(TCompactionStatusUpdate) - Constructor for class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
Performs a deep copy on other.
TCompactionStatusUpdate._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCompactionType - Enum in org.apache.accumulo.core.tabletserver.thrift
 
TCondition - Class in org.apache.accumulo.core.dataImpl.thrift
 
TCondition() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
TCondition(ByteBuffer, ByteBuffer, ByteBuffer, long, boolean, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
TCondition(TCondition) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TCondition
Performs a deep copy on other.
TCondition._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TConditionalMutation - Class in org.apache.accumulo.core.dataImpl.thrift
 
TConditionalMutation() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
TConditionalMutation(List<TCondition>, TMutation, long) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
TConditionalMutation(TConditionalMutation) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
Performs a deep copy on other.
TConditionalMutation._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TConditionalSession - Class in org.apache.accumulo.core.dataImpl.thrift
 
TConditionalSession() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
TConditionalSession(long, String, long) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
TConditionalSession(TConditionalSession) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
Performs a deep copy on other.
TConditionalSession._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TConstraintViolationSummary - Class in org.apache.accumulo.core.dataImpl.thrift
 
TConstraintViolationSummary() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
TConstraintViolationSummary(String, short, String, long) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
TConstraintViolationSummary(TConstraintViolationSummary) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
Performs a deep copy on other.
TConstraintViolationSummary._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TCredentials - Class in org.apache.accumulo.core.securityImpl.thrift
 
TCredentials() - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
TCredentials(String, String, ByteBuffer, String) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
TCredentials(TCredentials) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TCredentials
Performs a deep copy on other.
TCredentials._Fields - Enum in org.apache.accumulo.core.securityImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TDelegationToken - Class in org.apache.accumulo.core.securityImpl.thrift
 
TDelegationToken() - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
TDelegationToken(ByteBuffer, TAuthenticationTokenIdentifier) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
TDelegationToken(TDelegationToken) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
Performs a deep copy on other.
TDelegationToken._Fields - Enum in org.apache.accumulo.core.securityImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TDelegationTokenConfig - Class in org.apache.accumulo.core.securityImpl.thrift
 
TDelegationTokenConfig() - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
TDelegationTokenConfig(TDelegationTokenConfig) - Constructor for class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
Performs a deep copy on other.
TDelegationTokenConfig._Fields - Enum in org.apache.accumulo.core.securityImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TDiskUsage - Class in org.apache.accumulo.core.clientImpl.thrift
 
TDiskUsage() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
TDiskUsage(List<String>, long) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
TDiskUsage(TDiskUsage) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
Performs a deep copy on other.
TDiskUsage._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TDurability - Enum in org.apache.accumulo.core.tabletingest.thrift
 
term - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
TERM - org.apache.accumulo.core.security.ColumnVisibility.NodeType
 
TermSource(OrIterator.TermSource) - Constructor for class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
TermSource(SortedKeyValueIterator<Key, Value>, Text) - Constructor for class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
TermSource(SortedKeyValueIterator<Key, Value>, Text) - Constructor for class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
TermSource(SortedKeyValueIterator<Key, Value>, Text, boolean) - Constructor for class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
TermSource(IntersectingIterator.TermSource) - Constructor for class org.apache.accumulo.core.iterators.user.IntersectingIterator.TermSource
 
test(String) - Method in class org.apache.accumulo.core.conf.PropertyType.PortRange
 
testClassLoad(String, String) - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Test to see if the instance can load the given class as the given type.
testClassLoad(String, String) - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
testClassLoad(String, String, String) - Method in interface org.apache.accumulo.core.client.admin.NamespaceOperations
Test to see if the instance can load the given class as the given type.
testClassLoad(String, String, String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations
Test to see if the instance can load the given class as the given type.
testClassLoad(String, String, String) - Method in class org.apache.accumulo.core.clientImpl.NamespaceOperationsImpl
 
testClassLoad(String, String, String) - Method in class org.apache.accumulo.core.clientImpl.TableOperationsImpl
 
testEncoder(Encoder<V>, V) - Static method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Tests whether v remains the same when encoded and decoded with the given encoder.
testEncoder(V) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Tests whether v remains the same when encoded and decoded with the current encoder.
TExternalCompaction - Class in org.apache.accumulo.core.compaction.thrift
 
TExternalCompaction() - Constructor for class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
TExternalCompaction(String, String, Map<Long, TCompactionStatusUpdate>, TExternalCompactionJob) - Constructor for class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
TExternalCompaction(TExternalCompaction) - Constructor for class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
Performs a deep copy on other.
TExternalCompaction._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TExternalCompactionJob - Class in org.apache.accumulo.core.tabletserver.thrift
 
TExternalCompactionJob() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
TExternalCompactionJob(String, TKeyExtent, List<InputFile>, IteratorConfig, String, boolean, TCompactionKind, long, Map<String, String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
TExternalCompactionJob(TExternalCompactionJob) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
Performs a deep copy on other.
TExternalCompactionJob._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.
TExternalCompactionList - Class in org.apache.accumulo.core.compaction.thrift
 
TExternalCompactionList() - Constructor for class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
TExternalCompactionList(Map<String, TExternalCompaction>) - Constructor for class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
TExternalCompactionList(TExternalCompactionList) - Constructor for class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
Performs a deep copy on other.
TExternalCompactionList._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TextLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder that preserves a Text's native sort order.
TextLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.TextLexicoder
 
TextUtil - Class in org.apache.accumulo.core.util
 
TextUtil() - Constructor for class org.apache.accumulo.core.util.TextUtil
 
threadPools() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
ThreadPools - Class in org.apache.accumulo.core.util.threads
 
ThreadPools.ExecutionError - Error in org.apache.accumulo.core.util.threads
 
threads(int) - Method in interface org.apache.accumulo.core.client.admin.TableOperations.ImportMappingOptions
Files are examined to determine where to load them.
threads(int) - Method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
Threads - Class in org.apache.accumulo.core.util.threads
 
Threads() - Constructor for class org.apache.accumulo.core.util.threads.Threads
 
Threads.AccumuloDaemonThread - Class in org.apache.accumulo.core.util.threads
 
THRESHOLD_OPT - Static variable in class org.apache.accumulo.core.client.admin.compaction.TooManyDeletesSelector
This option should be a floating point number between 1 and 0.
THRESHOLD_OPT_DEFAULT - Static variable in class org.apache.accumulo.core.client.admin.compaction.TooManyDeletesSelector
The default threshold.
thriftAssignmentsOut() - Method in class org.apache.accumulo.core.manager.balancer.AssignmentParamsImpl
 
ThriftClientTypes<C extends org.apache.thrift.TServiceClient> - Class in org.apache.accumulo.core.rpc.clients
 
ThriftClientTypes(String, TServiceClientFactory<C>) - Constructor for class org.apache.accumulo.core.rpc.clients.ThriftClientTypes
 
ThriftClientTypes.Exec<R,​C> - Interface in org.apache.accumulo.core.rpc.clients
execute method with supplied client returning object of type R
ThriftClientTypes.ExecVoid<C> - Interface in org.apache.accumulo.core.rpc.clients
execute method with supplied client
ThriftConcurrentModificationException - Exception in org.apache.accumulo.core.clientImpl.thrift
 
ThriftConcurrentModificationException() - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
ThriftConcurrentModificationException(String) - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
ThriftConcurrentModificationException(ThriftConcurrentModificationException) - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
Performs a deep copy on other.
ThriftConcurrentModificationException._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
thriftCurrentMigrations() - Method in class org.apache.accumulo.core.manager.balancer.BalanceParamsImpl
 
thriftCurrentStatus() - Method in class org.apache.accumulo.core.manager.balancer.AssignmentParamsImpl
 
thriftCurrentStatus() - Method in class org.apache.accumulo.core.manager.balancer.BalanceParamsImpl
 
ThriftMessageUtil - Class in org.apache.accumulo.core.util
Serializes and deserializes Thrift messages to and from byte arrays.
ThriftMessageUtil() - Constructor for class org.apache.accumulo.core.util.ThriftMessageUtil
 
ThriftNotActiveServiceException - Exception in org.apache.accumulo.core.clientImpl.thrift
 
ThriftNotActiveServiceException() - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
ThriftNotActiveServiceException(String, String) - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
ThriftNotActiveServiceException(ThriftNotActiveServiceException) - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
Performs a deep copy on other.
ThriftNotActiveServiceException._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftPropertyException - Exception in org.apache.accumulo.core.manager.thrift
 
ThriftPropertyException() - Constructor for exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
ThriftPropertyException(String, String, String) - Constructor for exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
ThriftPropertyException(ThriftPropertyException) - Constructor for exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
Performs a deep copy on other.
ThriftPropertyException._Fields - Enum in org.apache.accumulo.core.manager.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftScanner - Class in org.apache.accumulo.core.clientImpl
 
ThriftScanner() - Constructor for class org.apache.accumulo.core.clientImpl.ThriftScanner
 
ThriftScanner.ScanState - Class in org.apache.accumulo.core.clientImpl
 
ThriftScanner.ScanTimedOutException - Exception in org.apache.accumulo.core.clientImpl
 
ThriftSecurityException - Exception in org.apache.accumulo.core.clientImpl.thrift
 
ThriftSecurityException() - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
ThriftSecurityException(String, SecurityErrorCode) - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
ThriftSecurityException(ThriftSecurityException) - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
Performs a deep copy on other.
ThriftSecurityException._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTableOperationException - Exception in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTableOperationException() - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
ThriftTableOperationException(String, String, TableOperation, TableOperationExceptionType, String) - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
ThriftTableOperationException(ThriftTableOperationException) - Constructor for exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
Performs a deep copy on other.
ThriftTableOperationException._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest
 
ThriftTest.AsyncClient - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncClient.Factory - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncClient.fails_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncClient.success_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncClient.throwsError_call - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncIface - Interface in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncProcessor<I extends ThriftTest.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncProcessor.fails<I extends ThriftTest.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncProcessor.success<I extends ThriftTest.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.AsyncProcessor.throwsError<I extends ThriftTest.AsyncIface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.Client - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.Client.Factory - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.fails_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.fails_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.fails_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.fails_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.Iface - Interface in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.Processor<I extends ThriftTest.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.Processor.fails<I extends ThriftTest.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.Processor.success<I extends ThriftTest.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.Processor.throwsError<I extends ThriftTest.Iface> - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.success_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.success_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.success_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.success_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.throwsError_args - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.throwsError_args._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTest.throwsError_result - Class in org.apache.accumulo.core.clientImpl.thrift
 
ThriftTest.throwsError_result._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThriftTransportKey - Class in org.apache.accumulo.core.clientImpl
 
ThriftTransportKey(HostAndPort, long, ClientContext) - Constructor for class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
ThriftTransportPool - Class in org.apache.accumulo.core.clientImpl
 
ThriftTransportPool.TransportPoolShutdownException - Exception in org.apache.accumulo.core.clientImpl
 
thriftUnassigned() - Method in class org.apache.accumulo.core.manager.balancer.AssignmentParamsImpl
 
ThriftUtil - Class in org.apache.accumulo.core.rpc
Factory methods for creating Thrift client objects
ThriftUtil() - Constructor for class org.apache.accumulo.core.rpc.ThriftUtil
 
ThrottledBalancerProblemReporter - Class in org.apache.accumulo.core.spi.balancer.util
Throttles logging of balancer problems by storing the last log time for each problem and limiting reports to once per minute.
ThrottledBalancerProblemReporter(Class<?>) - Constructor for class org.apache.accumulo.core.spi.balancer.util.ThrottledBalancerProblemReporter
 
ThrottledBalancerProblemReporter.OutstandingMigrationsProblem - Interface in org.apache.accumulo.core.spi.balancer.util
 
ThrottledBalancerProblemReporter.Problem - Interface in org.apache.accumulo.core.spi.balancer.util
 
throwsError() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncProcessor.throwsError
 
throwsError() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Processor.throwsError
 
throwsError() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Client
 
throwsError() - Method in interface org.apache.accumulo.core.clientImpl.thrift.ThriftTest.Iface
 
throwsError(AsyncMethodCallback<Boolean>) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient
 
throwsError(AsyncMethodCallback<Boolean>) - Method in interface org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncIface
 
throwsError_args() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
throwsError_args(ThriftTest.throwsError_args) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
Performs a deep copy on other.
throwsError_call(AsyncMethodCallback<Boolean>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.throwsError_call
 
throwsError_result() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
throwsError_result(boolean, ThriftSecurityException) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
throwsError_result(ThriftTest.throwsError_result) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
Performs a deep copy on other.
tid - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
tid - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
TID - org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
 
TID - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args._Fields
 
TIME - org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
 
TIME_COLUMN - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
TIME_QUAL - Static variable in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
Holds the TimeType
timeCreated(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
timeCreated(long) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Retrieve the creation time of a FaTE transaction.
timeCreated(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
TimedOutException - Exception in org.apache.accumulo.core.client
 
TimedOutException(String) - Constructor for exception org.apache.accumulo.core.client.TimedOutException
 
TimedOutException(Set<String>) - Constructor for exception org.apache.accumulo.core.client.TimedOutException
 
TIMEDURATION - org.apache.accumulo.core.conf.PropertyType
 
timeout - Variable in class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
TimeoutTabletLocator - Class in org.apache.accumulo.core.clientImpl
Throws a TimedOutException if the specified timeout duration elapses between two failed TabletLocator calls.
TimeoutTabletLocator(long, ClientContext, TableId) - Constructor for class org.apache.accumulo.core.clientImpl.TimeoutTabletLocator
 
TIMES_PAUSED - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
TimeSettingIterator - Class in org.apache.accumulo.core.iteratorsImpl.system
 
TimeSettingIterator(SortedKeyValueIterator<Key, Value>, long) - Constructor for class org.apache.accumulo.core.iteratorsImpl.system.TimeSettingIterator
 
timesPaused - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
timestamp - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
timestamp - Variable in class org.apache.accumulo.core.data.Key
 
timestamp - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
timestamp - Variable in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
timestamp - Variable in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
timestamp(long) - Method in interface org.apache.accumulo.core.data.KeyBuilder.Build
Change the timestamp of the Key created.
timestamp(long) - Method in interface org.apache.accumulo.core.data.Mutation.TimestampOptions
 
TIMESTAMP - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
TIMESTAMP - org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
 
TIMESTAMP - org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
 
TimestampFilter - Class in org.apache.accumulo.core.iterators.user
A Filter that matches entries whose timestamps fall within a range.
TimestampFilter() - Constructor for class org.apache.accumulo.core.iterators.user.TimestampFilter
 
TimeType - Enum in org.apache.accumulo.core.client.admin
The type of ordering to use for the table's entries (default is MILLIS)
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
tinfo - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
tinfo - Variable in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
tinfo - Variable in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
tinfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
tinfo - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
tinfo - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
tinfo - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
TInfo - Class in org.apache.accumulo.core.clientImpl.thrift
 
TInfo() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
TInfo(Map<String, String>) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
TInfo(TInfo) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TInfo
Performs a deep copy on other.
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
 
TINFO - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args._Fields
 
TINFO - org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args._Fields
 
TINFO - org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args._Fields
 
TINFO - org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
 
TINFO - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args._Fields
 
TINFO - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args._Fields
 
TINFO - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args._Fields
 
TINFO - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args._Fields
 
TINFO - org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args._Fields
 
TINFO - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args._Fields
 
TINFO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args._Fields
 
TINFO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args._Fields
 
TINFO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args._Fields
 
TINFO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args._Fields
 
TINFO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args._Fields
 
TINFO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
 
TINFO - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args._Fields
 
TINFO - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args._Fields
 
TInfo._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TinyLfuBlockCache - Class in org.apache.accumulo.core.file.blockfile.cache.tinylfu
A block cache that is memory bounded using the W-TinyLFU eviction algorithm.
TinyLfuBlockCache(BlockCacheManager.Configuration, CacheType) - Constructor for class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCache
 
TinyLfuBlockCacheManager - Class in org.apache.accumulo.core.file.blockfile.cache.tinylfu
 
TinyLfuBlockCacheManager() - Constructor for class org.apache.accumulo.core.file.blockfile.cache.tinylfu.TinyLfuBlockCacheManager
 
TIteratorSetting - Class in org.apache.accumulo.core.tabletserver.thrift
 
TIteratorSetting() - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
TIteratorSetting(int, String, String, Map<String, String>) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
TIteratorSetting(TIteratorSetting) - Constructor for class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
Performs a deep copy on other.
TIteratorSetting._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.
TKey - Class in org.apache.accumulo.core.dataImpl.thrift
 
TKey() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKey
 
TKey(ByteBuffer, ByteBuffer, ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKey
 
TKey(TKey) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKey
Performs a deep copy on other.
TKey._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TKeyExtent - Class in org.apache.accumulo.core.dataImpl.thrift
 
TKeyExtent() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
TKeyExtent(ByteBuffer, ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
TKeyExtent(TKeyExtent) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
Performs a deep copy on other.
TKeyExtent._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TKeyValue - Class in org.apache.accumulo.core.dataImpl.thrift
 
TKeyValue() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
TKeyValue(TKey, ByteBuffer) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
TKeyValue(TKeyValue) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
Performs a deep copy on other.
TKeyValue._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tmfe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
tmfe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
TMFE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
 
TMFE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
 
TMutation - Class in org.apache.accumulo.core.dataImpl.thrift
 
TMutation() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
TMutation(ByteBuffer, ByteBuffer, List<ByteBuffer>, int) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
TMutation(TMutation) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TMutation
Performs a deep copy on other.
TMutation._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
tnase - Variable in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
tnase - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
TNASE - org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result._Fields
 
TNASE - org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
 
to(OutputStream) - Method in interface org.apache.accumulo.core.client.rfile.RFile.OutputArguments
 
to(CharSequence, CharSequence) - Method in interface org.apache.accumulo.core.client.AccumuloClient.InstanceArgs
 
to(CharSequence, CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
to(String) - Method in interface org.apache.accumulo.core.client.admin.TableOperations.ImportDestinationArguments
 
to(String) - Method in interface org.apache.accumulo.core.client.rfile.RFile.OutputArguments
 
to(String) - Method in class org.apache.accumulo.core.clientImpl.bulk.BulkImport
 
TO_AUTH - org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
 
toAccumuloConf(Properties) - Static method in class org.apache.accumulo.core.clientImpl.ClientConfConverter
 
toArray() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
toArray() - Method in class org.apache.accumulo.core.data.ByteSequence
Returns a byte array containing the bytes in this sequence.
toArray() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
Gets (a copy of) the contents of this writer's buffer.
toAuth - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
toByteArrayInputStream(ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toByteBuffer() - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
Gets a ByteBuffer wrapped around this writer's buffer.
toByteBuffers(Collection<byte[]>) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toByteBuffers(ByteSequence) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toBytes(ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toBytesList(Collection<ByteBuffer>) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toColumn() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
toDataRange() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Compute a representation of this extent as a Range suitable for scanning this extent's table and retrieving all data between this extent's previous end row (exclusive) and its end row (inclusive) in that table (or another table in the same range, since the returned range does not specify the table to scan).
toe - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
TOE - org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
 
toHexString(long) - Static method in class org.apache.accumulo.core.util.FastFormat
Create a zero padded string from a hexadecimal number.
toHexString(String, long, String) - Static method in class org.apache.accumulo.core.util.FastFormat
Create a zero padded string from a hexadecimal number.
toIndexReaderBuilderOptions(Cache<String, Long>) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
toIteratorConfig(List<IteratorSetting>) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.SystemIteratorUtil
 
toIteratorSetting(TIteratorSetting) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.SystemIteratorUtil
 
toJson() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
toJson() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
toJson() - Method in class org.apache.accumulo.core.metadata.schema.RootTabletMetadata
 
token - Variable in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
token() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
TOKEN - org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
 
TOKEN_CLASS_NAME - org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
 
TOKEN_EXPIRED - org.apache.accumulo.core.client.security.SecurityErrorCode
 
TOKEN_EXPIRED - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
TOKEN_KIND - Static variable in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
tokenClassName - Variable in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
TokenProperty(String, String, boolean) - Constructor for class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
toKeyExtent() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
toKeyExtent(TableId) - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Tablet
 
toKeyExtent(TableId, Bulk.Tablet) - Static method in class org.apache.accumulo.core.clientImpl.bulk.Bulk
 
toMap(Properties) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
toMapEntry() - Method in class org.apache.accumulo.core.util.Pair
 
toMetaRange() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Compute a representation of this extent as a Range suitable for scanning the corresponding metadata table for this extent's table, and retrieving all the metadata for the table's tablets between this extent's previous end row (exclusive) and its end row (inclusive) in that table.
toMetaRow() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Return a serialized form of the table ID and end row for this extent, in a form suitable for use in the row portion of metadata entries for the tablet this extent represents.
TOO_LONG_STAT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
This is the name of the statistic that tracks how many counter objects were ignored because they were too long.
TOO_MANY_STAT - Static variable in class org.apache.accumulo.core.client.summary.CountingSummarizer
This is the name of the statistic that tracks how many counters objects were ignored because the number of unique counters was exceeded.
TooManyDeletesSelector - Class in org.apache.accumulo.core.client.admin.compaction
This compaction selector works in concert with the DeletesSummarizer.
TooManyDeletesSelector() - Constructor for class org.apache.accumulo.core.client.admin.compaction.TooManyDeletesSelector
 
TooManyFilesException - Exception in org.apache.accumulo.core.tabletscan.thrift
 
TooManyFilesException() - Constructor for exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
TooManyFilesException(TKeyExtent) - Constructor for exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
TooManyFilesException(TooManyFilesException) - Constructor for exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
Performs a deep copy on other.
TooManyFilesException._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
top(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
top(long) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Get the current operation for the given transaction id.
top(long) - Method in interface org.apache.accumulo.core.fate.TStore
 
top(long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
tope - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
tope - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
tope - Variable in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
 
TOPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
 
TOPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
 
TOPE - org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result._Fields
 
topKey - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
toPrefix() - Method in enum org.apache.accumulo.core.file.FilePrefix
 
toPrintableString(byte[], int, int, int) - Static method in class org.apache.accumulo.core.data.Key
Returns an ASCII printable string form of the given byte array, treating the bytes as ASCII characters.
toProperties(String) - Static method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
toProperties(URL) - Static method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
toProperties(Path) - Static method in class org.apache.accumulo.core.clientImpl.ClientInfoImpl
 
toProperties(AccumuloConfiguration) - Static method in class org.apache.accumulo.core.clientImpl.ClientConfConverter
 
toRange() - Method in interface org.apache.accumulo.core.data.TabletId
 
toRange() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
toRange() - Method in class org.apache.accumulo.core.summary.Gatherer.RowRange
 
toReaderBuilderOptions(CacheProvider, Cache<String, Long>, boolean) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
toSamplerConfiguration() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
toScanReaderBuilderOptions(Range, Set<ByteSequence>, boolean) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
toService(String) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatch.ServiceBuilder
 
toService(CompactionServiceId) - Method in interface org.apache.accumulo.core.spi.compaction.CompactionDispatch.ServiceBuilder
 
toStoredTabletFile(CompactableFile) - Static method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
toString() - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
toString() - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
toString() - Method in class org.apache.accumulo.core.client.admin.CompactionConfig
 
toString() - Method in class org.apache.accumulo.core.client.admin.DelegationTokenConfig
 
toString() - Method in class org.apache.accumulo.core.client.admin.DiskUsage
 
toString() - Method in class org.apache.accumulo.core.client.admin.PluginConfig
 
toString() - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
toString() - Method in class org.apache.accumulo.core.client.IteratorSetting
 
toString() - Method in class org.apache.accumulo.core.client.sample.SamplerConfiguration
 
toString() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.TokenProperty
 
toString() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
 
toString() - Method in class org.apache.accumulo.core.client.summary.Summary.FileStatistics
 
toString() - Method in class org.apache.accumulo.core.client.summary.Summary
 
toString() - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
toString() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.FileInfo
 
toString() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Files
 
toString() - Method in class org.apache.accumulo.core.clientImpl.bulk.Bulk.Tablet
 
toString() - Method in class org.apache.accumulo.core.clientImpl.CloneConfigurationImpl
 
toString() - Method in class org.apache.accumulo.core.clientImpl.Credentials
 
toString() - Method in class org.apache.accumulo.core.clientImpl.TabletLocator.TabletLocation
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
toString() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
toString() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
toString() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
toString() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
toString() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
toString() - Method in class org.apache.accumulo.core.clientImpl.ThriftTransportKey
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
toString() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
toString() - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
toString() - Method in enum org.apache.accumulo.core.conf.Property
 
toString() - Method in enum org.apache.accumulo.core.conf.PropertyType
 
toString() - Method in class org.apache.accumulo.core.crypto.CryptoEnvironmentImpl
 
toString() - Method in class org.apache.accumulo.core.data.AbstractId
Returns a string of the canonical ID.
toString() - Method in class org.apache.accumulo.core.data.ArrayByteSequence
 
toString() - Method in class org.apache.accumulo.core.data.Column
Gets a string representation of this column.
toString() - Method in class org.apache.accumulo.core.data.ColumnUpdate
 
toString() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
toString() - Method in class org.apache.accumulo.core.data.Key
 
toString() - Method in class org.apache.accumulo.core.data.Range
 
toString() - Method in class org.apache.accumulo.core.data.Value
 
toString() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
 
toString() - Method in class org.apache.accumulo.core.dataImpl.TabletIdImpl
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
toString() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
toString() - Method in class org.apache.accumulo.core.fate.zookeeper.FateLock.FateLockPath
 
toString() - Method in class org.apache.accumulo.core.fate.zookeeper.ZooUtil.LockID
 
toString() - Method in class org.apache.accumulo.core.file.blockfile.cache.impl.BlockCacheConfiguration
 
toString() - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration
 
toString() - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
 
toString() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex.BlockIndexEntry
 
toString() - Method in class org.apache.accumulo.core.gc.ReferenceFile
 
toString() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
toString() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
toString() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
toString() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
toString() - Method in class org.apache.accumulo.core.iterators.OrIterator.TermSource
 
toString() - Method in class org.apache.accumulo.core.iterators.user.SeekingFilter.FilterResult
 
toString() - Method in class org.apache.accumulo.core.lock.ServiceLock.ServiceLockPath
 
toString() - Method in class org.apache.accumulo.core.lock.ServiceLockData.ServiceDescriptor
 
toString() - Method in class org.apache.accumulo.core.lock.ServiceLockData
 
toString() - Method in class org.apache.accumulo.core.manager.balancer.TableStatisticsImpl
 
toString() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
toString() - Method in class org.apache.accumulo.core.manager.balancer.TabletStatisticsImpl
 
toString() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
toString() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
toString() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
toString() - Method in class org.apache.accumulo.core.metadata.CompactableFileImpl
 
toString() - Method in class org.apache.accumulo.core.metadata.ReferencedTabletFile
 
toString() - Method in class org.apache.accumulo.core.metadata.ScanServerRefTabletFile
 
toString() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
toString() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState
 
toString() - Method in class org.apache.accumulo.core.metadata.schema.ExternalCompactionMetadata
 
toString() - Method in class org.apache.accumulo.core.metadata.schema.TabletMetadata.Location
 
toString() - Method in class org.apache.accumulo.core.metadata.StoredTabletFile
 
toString() - Method in class org.apache.accumulo.core.metadata.SuspendingTServer
 
toString() - Method in class org.apache.accumulo.core.metadata.TabletLocationState
 
toString() - Method in class org.apache.accumulo.core.metadata.TServerInstance
 
toString() - Method in class org.apache.accumulo.core.metadata.UnreferencedTabletFile
 
toString() - Method in class org.apache.accumulo.core.rpc.SaslClientDigestCallbackHandler
 
toString() - Method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
 
toString() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
toString() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
toString() - Method in class org.apache.accumulo.core.security.Authorizations
 
toString() - Method in class org.apache.accumulo.core.security.ColumnVisibility
 
toString() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
toString() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
toString() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
toString() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
toString() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
toString() - Method in class org.apache.accumulo.core.spi.balancer.data.TabletMigration
 
toString() - Method in class org.apache.accumulo.core.spi.balancer.HostRegexTableLoadBalancer
 
toString() - Method in class org.apache.accumulo.core.summary.Gatherer.RowRange
 
toString() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
toString() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
toString() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
toString() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
toString() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
toString() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
toString() - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
toString() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
toString() - Method in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
toString() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
toString() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
toString() - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
toString() - Method in class org.apache.accumulo.core.tabletserver.log.LogEntry
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
toString() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
toString() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
toString() - Method in class org.apache.accumulo.core.util.ColumnFQ
 
toString() - Method in class org.apache.accumulo.core.util.compaction.CompactionJobImpl
 
toString() - Method in class org.apache.accumulo.core.util.compaction.CompactionPlanImpl
 
toString() - Method in class org.apache.accumulo.core.util.compaction.RunningCompactionInfo
 
toString() - Method in class org.apache.accumulo.core.util.DurationFormat
 
toString() - Method in class org.apache.accumulo.core.util.OpTimer
Return the current elapsed time in nanoseconds as a string.
toString() - Method in class org.apache.accumulo.core.util.Pair
 
toString() - Method in class org.apache.accumulo.core.util.Stat
 
toString() - Method in class org.apache.accumulo.core.volume.VolumeImpl
 
toString(String, String, String) - Method in class org.apache.accumulo.core.util.Pair
 
toString(ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toStringNoTime() - Method in class org.apache.accumulo.core.data.Key
Converts this key to a string, not including timestamp or delete marker.
toStringNoTruncate() - Method in class org.apache.accumulo.core.data.Key
Stringify this Key, avoiding truncation of each component, only limiting each component to a length of Integer.MAX_VALUE
toStringSet(Collection<ByteBuffer>) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toTableId(ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toTableProperties() - Method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
Converts this configuration to Accumulo per table properties.
toTableProperties() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
toTableProperties(Collection<SummarizerConfiguration>) - Static method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
Encodes each configuration in the same way as SummarizerConfiguration.toTableProperties().
toTableProperties(SummarizerConfiguration...) - Static method in class org.apache.accumulo.core.client.summary.SummarizerConfiguration
Encodes each configuration in the same way as SummarizerConfiguration.toTableProperties().
toTablePropertiesMap() - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
toTablePropertiesMap(List<SummarizerConfiguration>) - Static method in class org.apache.accumulo.core.summary.SummarizerConfigurationUtil
 
toTablet(KeyExtent) - Static method in class org.apache.accumulo.core.clientImpl.bulk.Bulk
 
toTabletMetadata() - Method in class org.apache.accumulo.core.metadata.schema.RootTabletMetadata
Convert this class to a TabletMetadata
TOTAL_FILES - org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
 
TOTAL_STAT - Static variable in class org.apache.accumulo.core.client.summary.summarizers.DeletesSummarizer
The name of the statistics for the total number of keys.
totalFiles - Variable in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
toText(ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
toThrift() - Method in class org.apache.accumulo.core.data.Column
Converts this column to Thrift.
toThrift() - Method in class org.apache.accumulo.core.data.ConstraintViolationSummary
Converts this summary to Thrift.
toThrift() - Method in class org.apache.accumulo.core.data.Key
Converts this key to Thrift.
toThrift() - Method in class org.apache.accumulo.core.data.Mutation
Creates a TMutation object containing this Mutation's data.
toThrift() - Method in class org.apache.accumulo.core.data.Range
Converts this range to Thrift.
toThrift() - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Convert to Thrift form.
toThrift() - Method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
toThrift() - Method in class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
toThrift() - Method in class org.apache.accumulo.core.summary.Gatherer.RowRange
 
toThrift() - Method in class org.apache.accumulo.core.summary.SummaryCollection
 
toThrift() - Method in class org.apache.accumulo.core.util.LocalityGroupUtil.PartitionedMutation
 
toThrift(Durability) - Static method in class org.apache.accumulo.core.clientImpl.DurabilityImpl
 
toThrift(SamplerConfiguration) - Static method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
toThrift(SummarizerConfiguration) - Static method in class org.apache.accumulo.core.summary.SummarizerConfigurationUtil
 
toThrift(InstanceId) - Method in class org.apache.accumulo.core.clientImpl.Credentials
Converts the current object to the relevant thrift type.
toThrift(TabletServerId) - Static method in class org.apache.accumulo.core.manager.balancer.TabletServerIdImpl
 
toTIteratorSetting(IteratorSetting) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.SystemIteratorUtil
 
toValue(TServerInstance, long) - Static method in class org.apache.accumulo.core.metadata.SuspendingTServer
 
toWriterBuilderOptions(String, FSDataOutputStream, boolean) - Method in class org.apache.accumulo.core.file.FileOperations.FileHelper
 
toZeroPaddedHex(long) - Static method in class org.apache.accumulo.core.util.FastFormat
 
toZeroPaddedString(byte[], int, long, int, int, byte[]) - Static method in class org.apache.accumulo.core.util.FastFormat
 
toZeroPaddedString(long, int, int, byte[]) - Static method in class org.apache.accumulo.core.util.FastFormat
 
tpe - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
tpe - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
tpe - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
tpe - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
tpe - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
TPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
 
TPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
 
TPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
 
TPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
 
TPE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
 
trace - Variable in class org.apache.accumulo.core.cli.ClientOpts
 
traceInfo() - Static method in class org.apache.accumulo.core.trace.TraceUtil
Obtain TInfo for the current context.
TraceProtocolFactory - Class in org.apache.accumulo.core.rpc
TCompactProtocol.Factory implementation which uses a protocol which traces
TraceProtocolFactory() - Constructor for class org.apache.accumulo.core.rpc.TraceProtocolFactory
 
TraceUtil - Class in org.apache.accumulo.core.trace
 
TraceUtil() - Constructor for class org.apache.accumulo.core.trace.TraceUtil
 
TRange - Class in org.apache.accumulo.core.dataImpl.thrift
 
TRange() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TRange
 
TRange(TKey, TKey, boolean, boolean, boolean, boolean) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TRange
 
TRange(TRange) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TRange
Performs a deep copy on other.
TRange._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
transform(Key) - Method in class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
 
transform(Key) - Method in class org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor
 
transform(Key) - Method in interface org.apache.accumulo.core.file.keyfunctor.KeyFunctor
 
transform(Key) - Method in class org.apache.accumulo.core.file.keyfunctor.RowFunctor
 
transform(Range) - Method in class org.apache.accumulo.core.file.keyfunctor.ColumnFamilyFunctor
 
transform(Range) - Method in class org.apache.accumulo.core.file.keyfunctor.ColumnQualifierFunctor
 
transform(Range) - Method in interface org.apache.accumulo.core.file.keyfunctor.KeyFunctor
Implementations should return null if a range can not be converted to a bloom key.
transform(Range) - Method in class org.apache.accumulo.core.file.keyfunctor.RowFunctor
 
TransformingIterator - Class in org.apache.accumulo.core.iterators.user
The TransformingIterator allows portions of a key (except for the row) to be transformed.
TransformingIterator() - Constructor for class org.apache.accumulo.core.iterators.user.TransformingIterator
 
TransformingIterator.KVBuffer - Interface in org.apache.accumulo.core.iterators.user
 
transformKeys() - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Reads all keys matching the first key's prefix from the source iterator, transforms them, and sorts the resulting keys.
transformRange(SortedKeyValueIterator<Key, Value>, TransformingIterator.KVBuffer) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Transforms input.
transportFactory() - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
An instance of TFramedTransport.Factory
transportFactory(long) - Static method in class org.apache.accumulo.core.rpc.ThriftUtil
Get an instance of the TTransportFactory with the provided maximum frame size
TransportPoolShutdownException(String) - Constructor for exception org.apache.accumulo.core.clientImpl.ThriftTransportPool.TransportPoolShutdownException
 
TRowRange - Class in org.apache.accumulo.core.dataImpl.thrift
 
TRowRange() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
TRowRange(ByteBuffer, ByteBuffer) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
TRowRange(TRowRange) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TRowRange
Performs a deep copy on other.
TRowRange._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
truncate(Text) - Static method in class org.apache.accumulo.core.util.TextUtil
 
truncate(Text, int) - Static method in class org.apache.accumulo.core.util.TextUtil
 
truststore(CharSequence) - Method in interface org.apache.accumulo.core.client.AccumuloClient.SslOptions
Build with SSL trust store
truststore(CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
truststore(CharSequence, CharSequence, CharSequence) - Method in interface org.apache.accumulo.core.client.AccumuloClient.SslOptions
Build with SSL trust store
truststore(CharSequence, CharSequence, CharSequence) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
tryLock(ServiceLock.LockWatcher, ServiceLockData) - Method in class org.apache.accumulo.core.lock.ServiceLock
 
tryReserve(long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
tryReserve(long) - Method in interface org.apache.accumulo.core.fate.TStore
Attempt to reserve transaction
tryReserve(long) - Method in class org.apache.accumulo.core.fate.ZooStore
Attempt to reserve transaction
tryToCancelAsyncLockOrUnlock() - Method in class org.apache.accumulo.core.lock.ServiceLock
 
ts - Variable in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
TS - org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
TSampleNotPresentException - Exception in org.apache.accumulo.core.tabletscan.thrift
 
TSampleNotPresentException() - Constructor for exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
TSampleNotPresentException(TKeyExtent) - Constructor for exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
TSampleNotPresentException(TSampleNotPresentException) - Constructor for exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
Performs a deep copy on other.
TSampleNotPresentException._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TSamplerConfiguration - Class in org.apache.accumulo.core.tabletscan.thrift
 
TSamplerConfiguration() - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
TSamplerConfiguration(String, Map<String, String>) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
TSamplerConfiguration(TSamplerConfiguration) - Constructor for class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
Performs a deep copy on other.
TSamplerConfiguration._Fields - Enum in org.apache.accumulo.core.tabletscan.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TSERV - org.apache.accumulo.core.lock.ServiceLockData.ThriftService
 
TSERV_ASSIGNMENT_DURATION_WARNING - org.apache.accumulo.core.conf.Property
 
TSERV_ASSIGNMENT_MAXCONCURRENT - org.apache.accumulo.core.conf.Property
 
TSERV_BLOOM_LOAD_MAXCONCURRENT - org.apache.accumulo.core.conf.Property
 
TSERV_CACHE_MANAGER_IMPL - org.apache.accumulo.core.conf.Property
 
TSERV_CLIENT_TIMEOUT - org.apache.accumulo.core.conf.Property
 
TSERV_CLIENTPORT - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_DEFAULT_EXECUTORS - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_DEFAULT_MAX_OPEN - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_DEFAULT_PLANNER - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_DEFAULT_RATE_LIMIT - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_META_EXECUTORS - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_META_MAX_OPEN - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_META_PLANNER - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_META_RATE_LIMIT - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_PREFIX - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_ROOT_EXECUTORS - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_ROOT_MAX_OPEN - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_ROOT_PLANNER - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_SERVICE_ROOT_RATE_LIMIT - org.apache.accumulo.core.conf.Property
 
TSERV_COMPACTION_WARN_TIME - org.apache.accumulo.core.conf.Property
 
TSERV_DATACACHE_SIZE - org.apache.accumulo.core.conf.Property
 
TSERV_DEFAULT_BLOCKSIZE - org.apache.accumulo.core.conf.Property
 
TSERV_HEALTH_CHECK_FREQ - org.apache.accumulo.core.conf.Property
 
TSERV_HOLD_TIME_SUICIDE - org.apache.accumulo.core.conf.Property
 
TSERV_INDEXCACHE_SIZE - org.apache.accumulo.core.conf.Property
 
TSERV_LAST_LOCATION_MODE - org.apache.accumulo.core.conf.Property
 
TSERV_LOG_BUSY_TABLETS_COUNT - org.apache.accumulo.core.conf.Property
 
TSERV_LOG_BUSY_TABLETS_INTERVAL - org.apache.accumulo.core.conf.Property
 
TSERV_MAJC_DELAY - org.apache.accumulo.core.conf.Property
 
TSERV_MAX_IDLE - org.apache.accumulo.core.conf.Property
 
TSERV_MAX_MESSAGE_SIZE - org.apache.accumulo.core.conf.Property
 
TSERV_MAXMEM - org.apache.accumulo.core.conf.Property
 
TSERV_MEMDUMP_DIR - org.apache.accumulo.core.conf.Property
 
TSERV_MIGRATE_MAXCONCURRENT - org.apache.accumulo.core.conf.Property
 
TSERV_MINC_MAXCONCURRENT - org.apache.accumulo.core.conf.Property
 
TSERV_MINTHREADS - org.apache.accumulo.core.conf.Property
 
TSERV_MINTHREADS_TIMEOUT - org.apache.accumulo.core.conf.Property
 
TSERV_NATIVEMAP_ENABLED - org.apache.accumulo.core.conf.Property
 
TSERV_PORTSEARCH - org.apache.accumulo.core.conf.Property
 
TSERV_PREFIX - org.apache.accumulo.core.conf.Property
 
TSERV_SCAN_EXECUTORS_DEFAULT_PRIORITIZER - org.apache.accumulo.core.conf.Property
 
TSERV_SCAN_EXECUTORS_DEFAULT_THREADS - org.apache.accumulo.core.conf.Property
 
TSERV_SCAN_EXECUTORS_META_THREADS - org.apache.accumulo.core.conf.Property
 
TSERV_SCAN_EXECUTORS_PREFIX - org.apache.accumulo.core.conf.Property
 
TSERV_SCAN_MAX_OPENFILES - org.apache.accumulo.core.conf.Property
 
TSERV_SCAN_RESULTS_MAX_TIMEOUT - org.apache.accumulo.core.conf.Property
 
TSERV_SESSION_MAXIDLE - org.apache.accumulo.core.conf.Property
 
TSERV_SLOW_FILEPERMIT_MILLIS - org.apache.accumulo.core.conf.Property
 
TSERV_SLOW_FLUSH_MILLIS - org.apache.accumulo.core.conf.Property
 
TSERV_SUMMARY_PARTITION_THREADS - org.apache.accumulo.core.conf.Property
 
TSERV_SUMMARY_REMOTE_THREADS - org.apache.accumulo.core.conf.Property
 
TSERV_SUMMARY_RETRIEVAL_THREADS - org.apache.accumulo.core.conf.Property
 
TSERV_SUMMARYCACHE_SIZE - org.apache.accumulo.core.conf.Property
 
TSERV_TABLET_SPLIT_FINDMIDPOINT_MAXOPEN - org.apache.accumulo.core.conf.Property
 
TSERV_THREADCHECK - org.apache.accumulo.core.conf.Property
 
TSERV_TOTAL_MUTATION_QUEUE_MAX - org.apache.accumulo.core.conf.Property
 
TSERV_UPDATE_SESSION_MAXIDLE - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_BLOCKSIZE - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_MAX_AGE - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_MAX_REFERENCED - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_MAX_SIZE - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_REPLICATION - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_SORT_BUFFER_SIZE - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_SORT_FILE_PREFIX - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_SORT_MAX_CONCURRENT - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_SYNC - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_TOLERATED_CREATION_FAILURES - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_TOLERATED_MAXIMUM_WAIT_DURATION - org.apache.accumulo.core.conf.Property
 
TSERV_WAL_TOLERATED_WAIT_INCREMENT - org.apache.accumulo.core.conf.Property
 
TSERV_WORKQ_THREADS - org.apache.accumulo.core.conf.Property
 
TSERVER - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost.Type
 
TSERVER_LOCK - org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
 
TServerClient<C extends org.apache.thrift.TServiceClient> - Interface in org.apache.accumulo.core.rpc.clients
 
tServerInfo - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
TServerInstance - Class in org.apache.accumulo.core.metadata
A tablet is assigned to a tablet server at the given address as long as it is alive and well.
TServerInstance(HostAndPort, long) - Constructor for class org.apache.accumulo.core.metadata.TServerInstance
 
TServerInstance(HostAndPort, String) - Constructor for class org.apache.accumulo.core.metadata.TServerInstance
 
TServerInstance(String) - Constructor for class org.apache.accumulo.core.metadata.TServerInstance
 
TServerInstance(String, long) - Constructor for class org.apache.accumulo.core.metadata.TServerInstance
 
TServerInstance(Value, Text) - Constructor for class org.apache.accumulo.core.metadata.TServerInstance
 
tserverLock - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
TServerStatus - Interface in org.apache.accumulo.core.spi.balancer.data
 
TServerStatusImpl - Class in org.apache.accumulo.core.manager.balancer
 
TServerStatusImpl(TabletServerStatus) - Constructor for class org.apache.accumulo.core.manager.balancer.TServerStatusImpl
 
tsnpe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
tsnpe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
tsnpe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
tsnpe - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
TSNPE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result._Fields
 
TSNPE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
 
TSNPE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result._Fields
 
TSNPE - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
 
TStore<T> - Interface in org.apache.accumulo.core.fate
Transaction Store: a place to save transactions A transaction consists of a number of operations.
TSummaries - Class in org.apache.accumulo.core.dataImpl.thrift
 
TSummaries() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
TSummaries(boolean, long, long, long, List<TSummary>) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
TSummaries(TSummaries) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummaries
Performs a deep copy on other.
TSummaries._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TSummarizerConfiguration - Class in org.apache.accumulo.core.dataImpl.thrift
 
TSummarizerConfiguration() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
TSummarizerConfiguration(String, Map<String, String>, String) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
TSummarizerConfiguration(TSummarizerConfiguration) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
Performs a deep copy on other.
TSummarizerConfiguration._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TSummary - Class in org.apache.accumulo.core.dataImpl.thrift
 
TSummary() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
TSummary(Map<String, Long>, TSummarizerConfiguration, long, long, long) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
TSummary(TSummary) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummary
Performs a deep copy on other.
TSummary._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TSummaryRequest - Class in org.apache.accumulo.core.dataImpl.thrift
 
TSummaryRequest() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
TSummaryRequest(String, TRowRange, List<TSummarizerConfiguration>, String) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
TSummaryRequest(TSummaryRequest) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
Performs a deep copy on other.
TSummaryRequest._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTimeoutTransport - Class in org.apache.accumulo.core.rpc
A utility class for setting up a TTransport with various necessary configurations for ideal performance in Accumulo.
ttl - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
TTL - org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
 
TTLSet(Map<String, String>) - Constructor for class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter.TTLSet
 
TUnloadTabletGoal - Enum in org.apache.accumulo.core.tablet.thrift
 
TVersionedProperties - Class in org.apache.accumulo.core.clientImpl.thrift
 
TVersionedProperties() - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
TVersionedProperties(long, Map<String, String>) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
TVersionedProperties(TVersionedProperties) - Constructor for class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
Performs a deep copy on other.
TVersionedProperties._Fields - Enum in org.apache.accumulo.core.clientImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TX_NAME - org.apache.accumulo.core.fate.Fate.TxInfo
 
type - Variable in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
type - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
type - Variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
type - Variable in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
type(Collection<KeyExtent>) - Static method in enum org.apache.accumulo.core.clientImpl.TabletType
 
type(KeyExtent) - Static method in enum org.apache.accumulo.core.clientImpl.TabletType
 
TYPE - org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
 
TYPE - org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
 
TYPE - org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
TYPE - org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
 
TYPE - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
typedReduce(Key, Iterator<Long>) - Method in class org.apache.accumulo.core.iterators.user.MaxCombiner
 
typedReduce(Key, Iterator<Long>) - Method in class org.apache.accumulo.core.iterators.user.MinCombiner
 
typedReduce(Key, Iterator<Long>) - Method in class org.apache.accumulo.core.iterators.user.SummingCombiner
 
typedReduce(Key, Iterator<BigDecimal>) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalMaxCombiner
 
typedReduce(Key, Iterator<BigDecimal>) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalMinCombiner
 
typedReduce(Key, Iterator<BigDecimal>) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner.BigDecimalSummingCombiner
 
typedReduce(Key, Iterator<List<Long>>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
typedReduce(Key, Iterator<V>) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
Reduces a list of V into a single V.
TypedValueCombiner<V> - Class in org.apache.accumulo.core.iterators
A Combiner that decodes each Value to type V before reducing, then encodes the result of typedReduce back to Value.
TypedValueCombiner() - Constructor for class org.apache.accumulo.core.iterators.TypedValueCombiner
 

U

UEH - Static variable in class org.apache.accumulo.core.util.threads.Threads
 
ugi - Variable in class org.apache.accumulo.core.rpc.UGIAssumingTransport
 
UGIAssumingTransport - Class in org.apache.accumulo.core.rpc
The Thrift SASL transports call Sasl.createSaslServer and Sasl.createSaslClient inside open().
UGIAssumingTransport(TTransport, UserGroupInformation) - Constructor for class org.apache.accumulo.core.rpc.UGIAssumingTransport
 
UGIAssumingTransportFactory - Class in org.apache.accumulo.core.rpc
A TransportFactory that wraps another one, but assumes a specified UGI before calling through.
UGIAssumingTransportFactory(TTransportFactory, UserGroupInformation) - Constructor for class org.apache.accumulo.core.rpc.UGIAssumingTransportFactory
 
UIntegerLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for an unsigned integer.
UIntegerLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.UIntegerLexicoder
 
ULongLexicoder - Class in org.apache.accumulo.core.client.lexicoder
Unsigned long lexicoder.
ULongLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.ULongLexicoder
 
unableToMonitorLockNode(Exception) - Method in interface org.apache.accumulo.core.lock.ServiceLock.LockWatcher
lost the ability to monitor the lock node, and its status is unknown
unassigned(KeyExtent, int) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
UNASSIGNED - org.apache.accumulo.core.metadata.TabletState
 
UNASSIGNED - org.apache.accumulo.core.tablet.thrift.TUnloadTabletGoal
 
UNASSIGNED_TABLETS - org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
 
unassignedTablets - Variable in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unassignedTablets() - Method in class org.apache.accumulo.core.manager.balancer.AssignmentParamsImpl
 
unassignedTablets() - Method in interface org.apache.accumulo.core.spi.balancer.TabletBalancer.AssignmentParameters
 
unclosed(AutoCloseable, Class<?>, AtomicBoolean, Logger, AutoCloseable) - Static method in class org.apache.accumulo.core.util.cleaner.CleanerUtil
Register an action to warn about caller failing to close an AutoCloseable object.
undo(long, T) - Method in interface org.apache.accumulo.core.fate.Repo
 
unescape(byte[]) - Static method in class org.apache.accumulo.core.clientImpl.lexicoder.ByteUtils
Unescapes 0x00 0x01 0x01 with 0x00 and 0x01 0x01 0x2 with 0x01
UNKNOWN - org.apache.accumulo.core.client.ConditionalWriter.Status
error occurred after mutation was sent to server, its unknown if the mutation was written.
UNKNOWN - org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Unrecognized or unknown transaction state
UNKNOWN - org.apache.accumulo.core.manager.state.tables.TableState
 
UNKNOWN - org.apache.accumulo.core.tablet.thrift.TUnloadTabletGoal
 
UnknownCompactionIdException - Exception in org.apache.accumulo.core.compaction.thrift
 
UnknownCompactionIdException() - Constructor for exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
UnknownCompactionIdException(UnknownCompactionIdException) - Constructor for exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
Performs a deep copy on other.
UnknownCompactionIdException._Fields - Enum in org.apache.accumulo.core.compaction.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UNLOAD_ERROR - org.apache.accumulo.core.manager.thrift.TabletLoadState
 
UNLOAD_FAILURE_NOT_SERVING - org.apache.accumulo.core.manager.thrift.TabletLoadState
 
UNLOAD_METADATA_TABLETS - org.apache.accumulo.core.manager.thrift.ManagerState
 
UNLOAD_ROOT_TABLET - org.apache.accumulo.core.manager.thrift.ManagerState
 
UNLOADED - org.apache.accumulo.core.manager.thrift.TabletLoadState
 
unloadTablet() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncProcessor.unloadTablet
 
unloadTablet() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Processor.unloadTablet
 
unloadTablet(TInfo, TCredentials, String, TKeyExtent, TUnloadTabletGoal, long) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Client
 
unloadTablet(TInfo, TCredentials, String, TKeyExtent, TUnloadTabletGoal, long) - Method in interface org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.Iface
 
unloadTablet(TInfo, TCredentials, String, TKeyExtent, TUnloadTabletGoal, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient
 
unloadTablet(TInfo, TCredentials, String, TKeyExtent, TUnloadTabletGoal, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncIface
 
unloadTablet_args() - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
unloadTablet_args(TInfo, TCredentials, String, TKeyExtent, TUnloadTabletGoal, long) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
unloadTablet_args(TabletManagementClientService.unloadTablet_args) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
Performs a deep copy on other.
unloadTablet_call(TInfo, TCredentials, String, TKeyExtent, TUnloadTabletGoal, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.unloadTablet_call
 
unlock() - Method in class org.apache.accumulo.core.lock.ServiceLock
 
unnamedOptionDescriptions - Variable in class org.apache.accumulo.core.iterators.OptionDescriber.IteratorOptions
 
UnreferencedTabletFile - Class in org.apache.accumulo.core.metadata
A file that is not intended to be added to a tablet as a reference, within the scope of the code using this class, but needs to be passed to code that processes tablet files.
UnreferencedTabletFile(FileSystem, Path) - Constructor for class org.apache.accumulo.core.metadata.UnreferencedTabletFile
 
unreserve(long, long) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
unreserve(long, long) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Return the given transaction to the store.
unreserve(long, long) - Method in class org.apache.accumulo.core.fate.ZooStore
 
unsetAge() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetAge() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetArguments() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
unsetAuthorizationFailures() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetAuthorizations() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetAutoClean() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
unsetBadTServers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetBatch() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetBatchSize() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetBatchTimeOut() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetBatchTimeOut() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetBounds() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
unsetBulkImports() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetBulkImports() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetBulks() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
unsetBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
unsetBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetBusyTimeout() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetCandidates() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetCf() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
unsetCfg() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
unsetClassLoaderContext() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
unsetClassLoaderContext() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetClassLoaderContext() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetClassLoaderContext() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetClassname() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
unsetClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
unsetClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
unsetClassName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
unsetClassName() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
unsetClassName() - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
unsetClient() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetCmid() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
unsetCode() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
unsetColFamily() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
unsetColQualifier() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
unsetColumnFamily() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
unsetColumnQualifier() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
unsetColumns() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetColumns() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetColumns() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetColumnVisibility() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
unsetColVisibility() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
unsetCompactions() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
unsetCompactor() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
unsetCompactor() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
unsetCompactor() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
unsetConditions() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
unsetConfig() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
unsetConfigId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
unsetConstrainClass() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
unsetCount() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetCq() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
unsetCreationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
unsetCredentials() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
unsetCurrent() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetCurrentLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetCv() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
unsetCve() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
unsetData() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
unsetDataCacheHits() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetDataCacheRequest() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetDeadTabletServers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetDeleted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetDeletedFiles() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
unsetDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
unsetDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
unsetDescription() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
unsetDescription() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
unsetDir() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
unsetDurability() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
unsetDurability() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
unsetDurability() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
unsetElapsed() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
unsetEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
unsetEndRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
unsetEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
unsetEndRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
unsetEntries() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
unsetEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
unsetEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
unsetEntriesRead() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
unsetEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetEntriesRead() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
unsetEntriesToBeCompacted() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
unsetEntriesWritten() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
unsetEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetEntriesWritten() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
unsetErrors() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetEstimatedSize() - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
unsetEx() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
unsetExecutionHints() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetExecutionHints() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetExpirationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
unsetExpirationDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
unsetExtent() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
unsetExtent() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetExtent() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
unsetExtent() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetExtent() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetExtent() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
unsetExternalCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetFail() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetFailedExtents() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
unsetFailures() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
unsetFilename() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
unsetFilenames() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
unsetFiles() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
unsetFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
unsetFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetFilesContaining() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
unsetFilesExceeding() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
unsetFileSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
unsetFileSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
unsetFilesLarge() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
unsetFinished() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
unsetFinished() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetFlushID() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
unsetFlushs() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetForce() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
unsetFullScans() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
unsetGoal() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
unsetGoalState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetHasTimestamp() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
unsetHeaders() - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
unsetHoldTime() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
unsetIdentifier() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
unsetIdleTime() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetIndexCacheHits() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetIndexCacheRequest() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetInfiniteStartKey() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
unsetInfiniteStopKey() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
unsetIngestByteRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetIngestRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetIngestRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetInputFiles() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetInstanceId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
unsetInstanceId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
unsetInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
unsetInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
unsetInterfaceMatch() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
unsetInUse() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetIsolated() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetIssueDate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
unsetIteratorClass() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
unsetIterators() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
unsetIterators() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
unsetIteratorSettings() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetIterName() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
unsetJob() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
unsetKey() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
unsetKeyExtent() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
unsetKeyExtent() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
unsetKeyId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
unsetKeyId() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
unsetKind() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetLast() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetLastContact() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetLastLog() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
unsetLastStatus() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
unsetLifetime() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
unsetLocalityGroup() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetLock() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
unsetLock() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
unsetLock() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
unsetLock() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
unsetLock() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
unsetLogSorts() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetLookups() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetMajors() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetMajors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetMaxLoops() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
unsetMessage() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
unsetMetadataFileEntry() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
unsetMinors() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetMinors() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetModulus() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
unsetMore() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
unsetMore() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
unsetMutation() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
unsetMutation() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
unsetMutations() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
unsetMutations() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
unsetName() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
unsetName() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
unsetNamespaceId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
unsetNewTablets() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
unsetNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
unsetNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
unsetNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
unsetNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
unsetNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
unsetNs() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
unsetNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
unsetNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
unsetNs() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
unsetNssi() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
unsetNste() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
unsetNste() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
unsetNste() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
unsetNste() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
unsetNum() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetNumberOfViolatingMutations() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
unsetNumEntries() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetOldTablet() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
unsetOnlineTablets() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetOp() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
unsetOp() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
unsetOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
unsetOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
unsetOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
unsetOpid() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
unsetOptions() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
unsetOptions() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
unsetOptions() - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
unsetOsLoad() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetOutputFile() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetOverrides() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetPartNextKey() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
unsetPartNextKeyInclusive() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
unsetPartScan() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
unsetPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
unsetPassword() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
unsetPassword() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
unsetPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
unsetPermission() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
unsetPrevEndRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
unsetPrincipal() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
unsetPrincipal() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
unsetPriority() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
unsetPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
unsetPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
unsetPriority() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
unsetProgress() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
unsetPropagateDeletes() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetProperties() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
unsetProperties() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
unsetProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
unsetProperty() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
unsetProperty() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
unsetQueryByteRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetQueryRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetQueryRate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetQueue() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
unsetQueued() - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
unsetQueueName() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
unsetQueueName() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
unsetQueueName() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
unsetQueueSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetQueueTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetRange() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetReadaheadThreshold() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetReason() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetRecs() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetRecsInMemory() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetRemainder() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
unsetRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
unsetRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
unsetRequest() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
unsetRequestTime() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
unsetResponseTime() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetResult() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
unsetResult() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
unsetResults() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
unsetResults() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
unsetRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
unsetRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
unsetRunning() - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
unsetRuntime() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
unsetSamplerConfig() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetSamplerConfig() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetScanId() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetScanID() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
unsetScanID() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
unsetScanID() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
unsetScanID() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
unsetScanID() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
unsetScanID() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
unsetScanRate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetScans() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
unsetSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
unsetSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
unsetSec() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
unsetSec() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
unsetSec() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
unsetSec() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
unsetSec() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
unsetSecret() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
unsetServ() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
unsetServer() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
unsetServerName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
unsetServerName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
unsetServersShuttingDown() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetSessID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
unsetSessID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
unsetSessID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
unsetSessionId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
unsetSessionId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
unsetSessionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
unsetSetTime() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
unsetSize() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
unsetSources() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
unsetSplit() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
unsetSplitCreationTime() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetSplitPoint() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
unsetSplits() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
unsetSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
unsetSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
unsetSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
unsetSsbe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
unsetSsiList() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetSsiList() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetSsiList() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetSsiList() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetSsio() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetSsio() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetSsio() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetSsio() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetStart() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
unsetStarted() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
unsetStartKeyInclusive() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
unsetStartRow() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
unsetStartRow() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
unsetStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
unsetStartRow() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
unsetStartTime() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
unsetState() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
unsetState() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
unsetState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
unsetState() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetState() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetStats() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
unsetStatus() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
unsetStatus() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
unsetStatus() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
unsetStatus() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
unsetStatus() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetStop() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
unsetStopKeyInclusive() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
unsetStopTabletServers() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
unsetSuccess() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
unsetSumDev() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
unsetSummaries() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
unsetSummarizerPattern() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
unsetSummarizers() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
unsetSummary() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
unsetSymbols() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
unsetSyncs() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetSysPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
unsetTable() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
unsetTableId() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
unsetTableId() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
unsetTableId() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
unsetTableId() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
unsetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
unsetTableId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
unsetTableID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
unsetTableMap() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetTableMap() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
unsetTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
unsetTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
unsetTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
unsetTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
unsetTableName() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
unsetTableName() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
unsetTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
unsetTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
unsetTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
unsetTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
unsetTableName() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
unsetTables() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
unsetTables() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
unsetTablet() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
unsetTablets() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
unsetTabletServer() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
unsetTblNspcPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
unsetTblPerm() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
unsetTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
unsetTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
unsetTcme() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
unsetTid() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
unsetTid() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
unsetTimesPaused() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetTimestamp() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
unsetTimestamp() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
unsetTimestamp() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
unsetTinfo() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
unsetTmfe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
unsetTmfe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
unsetTnase() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
unsetToAuth() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
unsetToe() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
unsetToken() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
unsetTokenClassName() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
unsetTope() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
unsetTope() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
unsetTotalFiles() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
unsetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
unsetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
unsetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
unsetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
unsetTpe() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
unsetTs() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
unsetTServerInfo() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetTserverLock() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
unsetTsnpe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
unsetTsnpe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
unsetTsnpe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
unsetTsnpe() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
unsetTtl() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
unsetType() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
unsetType() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
unsetType() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetType() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
unsetUnassignedTablets() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
unsetUpdateID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
unsetUpdateID() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
unsetUpdates() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
unsetUsage() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
unsetUser() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
unsetUser() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
unsetUserCompactionId() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
unsetVal() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
unsetValue() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
unsetValue() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
unsetValue() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
unsetValue() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
unsetValue() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
unsetValues() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
unsetVersion() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
unsetVersion() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
unsetViolationCode() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
unsetViolationDescription() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
unsetViolationSummaries() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
unsetViolationSummaries() - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
unsetVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
unsetVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
unsetVProperties() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
unsetWaitForWrites() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
unsetWaitForWrites() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
UNSUPPORTED_OPERATION - org.apache.accumulo.core.client.security.SecurityErrorCode
 
UNSUPPORTED_OPERATION - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
unsuspended(KeyExtent) - Static method in class org.apache.accumulo.core.logging.TabletLogger
 
UnsynchronizedBuffer - Class in org.apache.accumulo.core.util
A utility class for reading and writing bytes to byte buffers without synchronization.
UnsynchronizedBuffer() - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer
 
UnsynchronizedBuffer.Reader - Class in org.apache.accumulo.core.util
A byte buffer reader.
UnsynchronizedBuffer.Writer - Class in org.apache.accumulo.core.util
A byte buffer writer.
untransformColumnFamilies(Collection<ByteSequence>) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
Reverses the transformation applied to column families that are fetched at seek time.
unwrap(Runnable) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
unwrap(Callable<T>) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
unwrapKey(byte[], Key) - Static method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
update() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncProcessor.update
 
update() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Processor.update
 
update() - Method in class org.apache.accumulo.core.util.ratelimit.SharedRateLimiterFactory.SharedRateLimiter
Poll the callback, updating the current rate if necessary.
update(TInfo, TCredentials, TKeyExtent, TMutation, TDurability) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Client
 
update(TInfo, TCredentials, TKeyExtent, TMutation, TDurability) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.Iface
 
update(TInfo, TCredentials, TKeyExtent, TMutation, TDurability, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient
 
update(TInfo, TCredentials, TKeyExtent, TMutation, TDurability, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncIface
 
update(Mutation) - Method in class org.apache.accumulo.core.clientImpl.Writer
 
update(Mutation) - Method in class org.apache.accumulo.core.metadata.schema.RootTabletMetadata
Apply a metadata table mutation to update internal entries.
update_args() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
update_args(TInfo, TCredentials, TKeyExtent, TMutation, TDurability) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
update_args(TabletIngestClientService.update_args) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
Performs a deep copy on other.
update_call(TInfo, TCredentials, TKeyExtent, TMutation, TDurability, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.update_call
 
UPDATE_ID - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args._Fields
 
UPDATE_ID - org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args._Fields
 
update_result() - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
update_result(ThriftSecurityException, NotServingTabletException, ConstraintViolationException) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
update_result(TabletIngestClientService.update_result) - Constructor for class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
Performs a deep copy on other.
updateBinningStats(int, long, Map<String, TabletLocator.TabletServerMutations<Mutation>>) - Method in class org.apache.accumulo.core.clientImpl.TabletServerBatchWriter
 
updateCompactionStatus() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncProcessor.updateCompactionStatus
 
updateCompactionStatus() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Processor.updateCompactionStatus
 
updateCompactionStatus(TInfo, TCredentials, String, TCompactionStatusUpdate, long) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Client
 
updateCompactionStatus(TInfo, TCredentials, String, TCompactionStatusUpdate, long) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.Iface
 
updateCompactionStatus(TInfo, TCredentials, String, TCompactionStatusUpdate, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient
 
updateCompactionStatus(TInfo, TCredentials, String, TCompactionStatusUpdate, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncIface
 
updateCompactionStatus_args() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
updateCompactionStatus_args(TInfo, TCredentials, String, TCompactionStatusUpdate, long) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
updateCompactionStatus_args(CompactionCoordinatorService.updateCompactionStatus_args) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
Performs a deep copy on other.
updateCompactionStatus_call(TInfo, TCredentials, String, TCompactionStatusUpdate, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.updateCompactionStatus_call
 
updateCompactionStatus_result() - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
updateCompactionStatus_result(CompactionCoordinatorService.updateCompactionStatus_result) - Constructor for class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
Performs a deep copy on other.
UpdateErrors - Class in org.apache.accumulo.core.dataImpl.thrift
 
UpdateErrors() - Constructor for class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
UpdateErrors(Map<TKeyExtent, Long>, List<TConstraintViolationSummary>, Map<TKeyExtent, SecurityErrorCode>) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
UpdateErrors(UpdateErrors) - Constructor for class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
Performs a deep copy on other.
UpdateErrors._Fields - Enum in org.apache.accumulo.core.dataImpl.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
updateFromConfiguration(Properties) - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
updateFromToken(AuthenticationToken) - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
updateID - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
updateID - Variable in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
updateKnownMessageSize(long) - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
updatePrincipalFromUgi() - Method in class org.apache.accumulo.core.rpc.SaslConnectionParams
 
updates - Variable in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
UPDATES - org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
 
updateScanIteratorOption(String, String, String) - Method in interface org.apache.accumulo.core.client.ScannerBase
Update the options for an iterator.
updateScanIteratorOption(String, String, String) - Method in class org.apache.accumulo.core.clientImpl.ScannerOptions
 
URI - org.apache.accumulo.core.conf.PropertyType
 
URLContextClassLoaderFactory - Class in org.apache.accumulo.core.classloader
The default implementation of ContextClassLoaderFactory.
URLContextClassLoaderFactory() - Constructor for class org.apache.accumulo.core.classloader.URLContextClassLoaderFactory
 
usage - Variable in class org.apache.accumulo.core.client.admin.DiskUsage
 
usage - Variable in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
USAGE - org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
 
usageGroup() - Method in class org.apache.accumulo.core.util.Help
 
usageGroup() - Method in class org.apache.accumulo.core.util.Version
 
USE_HINT - org.apache.accumulo.core.iterators.user.SeekingFilter.AdvanceResult
 
useClassCache(boolean) - Method in interface org.apache.accumulo.core.iteratorsImpl.IteratorBuilder.IteratorBuilderOptions
Option to iterator classes when loading, defaults to false.
useClassCache(boolean) - Method in class org.apache.accumulo.core.iteratorsImpl.IteratorBuilderImpl
 
useClassLoader(String) - Method in interface org.apache.accumulo.core.iteratorsImpl.IteratorBuilder.IteratorBuilderOptions
Call to use the class loader.
useClassLoader(String) - Method in class org.apache.accumulo.core.iteratorsImpl.IteratorBuilderImpl
 
useEvictionThread(boolean) - Method in class org.apache.accumulo.core.file.blockfile.cache.lru.LruBlockCacheConfiguration.Builder
 
useJsse() - Method in interface org.apache.accumulo.core.client.AccumuloClient.SslOptions
Use JSSE system properties to configure SSL
useJsse() - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
useJsse() - Method in class org.apache.accumulo.core.rpc.SslConnectionParams
 
user - Variable in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
user - Variable in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
USER - org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
compaction initiated by user
USER - org.apache.accumulo.core.clientImpl.TabletType
 
USER - org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
 
USER - org.apache.accumulo.core.metadata.schema.Ample.DataLevel
 
USER - org.apache.accumulo.core.spi.compaction.CompactionKind
A user initiated a one time compaction using an Accumulo client.
USER - org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
 
USER - org.apache.accumulo.core.tabletserver.thrift.TCompactionKind
 
USER - org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
 
USER_COMPACTION_ID - org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
 
USER_DOESNT_EXIST - org.apache.accumulo.core.client.security.SecurityErrorCode
 
USER_DOESNT_EXIST - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
USER_EXISTS - org.apache.accumulo.core.client.security.SecurityErrorCode
 
USER_EXISTS - org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
 
userCompactionId - Variable in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
UserCompactionUtils - Class in org.apache.accumulo.core.clientImpl
 
UserCompactionUtils() - Constructor for class org.apache.accumulo.core.clientImpl.UserCompactionUtils
 
UserCompactionUtils.Decoder<T> - Interface in org.apache.accumulo.core.clientImpl
 
UserCompactionUtils.Encoder<T> - Interface in org.apache.accumulo.core.clientImpl
 
UserCompactionUtils.PluginConfigData - Class in org.apache.accumulo.core.clientImpl
 
useRetry() - Method in class org.apache.accumulo.core.util.Retry
 
useSasl() - Method in interface org.apache.accumulo.core.client.AccumuloClient.ConnectionOptions
Build with SASL options
useSasl() - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
useSsl() - Method in interface org.apache.accumulo.core.client.AccumuloClient.ConnectionOptions
Build with SSL/TLS options
useSsl() - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
Utils - Class in org.apache.accumulo.core.file.rfile.bcfile
Supporting Utility classes used by TFile, and shared by users of TFile.
Utils.Version - Class in org.apache.accumulo.core.file.rfile.bcfile
A generic Version class.
UtilWaitThread - Class in org.apache.accumulo.core.util
 
UtilWaitThread() - Constructor for class org.apache.accumulo.core.util.UtilWaitThread
 
UUIDLexicoder - Class in org.apache.accumulo.core.client.lexicoder
A lexicoder for a UUID that maintains its lexicographic sorting order.
UUIDLexicoder() - Constructor for class org.apache.accumulo.core.client.lexicoder.UUIDLexicoder
 

V

V_PROPERTIES - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
 
V_PROPERTIES - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
 
V_PROPERTIES - org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
 
val - Variable in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
VAL - org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
 
VALID_RANGE - Static variable in class org.apache.accumulo.core.conf.PropertyType.PortRange
 
VALID_TABLE_ID - Static variable in class org.apache.accumulo.core.util.Validators
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
validate() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
validate() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
validate() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
validate() - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
validate() - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
validate() - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
validate() - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
validate() - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
validate() - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
validate() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
validate() - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
validate() - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
validate() - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
validate() - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
validate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
validate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
validate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
validate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
validate() - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
validate() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
validate() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
validate() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
validate() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
validate() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
validate() - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
validate() - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
validate() - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
validate() - Method in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
validate() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
validate() - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
validate() - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
validate() - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
validate() - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
validate(Iterable<Map.Entry<String, String>>, String) - Static method in class org.apache.accumulo.core.conf.ConfigCheckUtil
Validates the given configuration entries.
validate(String) - Static method in class org.apache.accumulo.core.metadata.StoredTabletFile
Validates that the provided metadata string for the StoredTabletFile is valid.
validate(String) - Static method in class org.apache.accumulo.core.metadata.ValidationUtil
Validate if string is a valid path.
validate(String, String) - Method in class org.apache.accumulo.core.file.rfile.CreateEmpty.IsSupportedCompressionAlgorithm
 
validate(String, String) - Method in class org.apache.accumulo.core.file.rfile.CreateEmpty.NamedLikeRFile
 
validate(Properties) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
validate(Properties, boolean) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
validate(ReferenceFile) - Static method in class org.apache.accumulo.core.metadata.ValidationUtil
 
validate(Path) - Static method in class org.apache.accumulo.core.metadata.ValidationUtil
 
validate(T) - Method in class org.apache.accumulo.core.util.Validator
Validates the provided argument.
validateAndSort(FateLock.FateLockPath, List<String>) - Static method in class org.apache.accumulo.core.fate.zookeeper.FateLock
Validate and sort child nodes at this lock path by the lock prefix
validateAndSort(ServiceLock.ServiceLockPath, List<String>) - Static method in class org.apache.accumulo.core.lock.ServiceLock
Sort list of ephemeral nodes by their sequence number.
validateDirCol(String) - Static method in class org.apache.accumulo.core.metadata.schema.MetadataSchema.TabletsSection.ServerColumnFamily
 
validateFileName(String) - Static method in class org.apache.accumulo.core.metadata.ValidationUtil
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.client.sample.AbstractHashSampler
Subclasses with options should override this method to validate subclass options while also calling super.validateOptions(config) to validate base class options.
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.client.sample.RowColumnSampler
 
validateOptions(Map<String, String>) - Method in interface org.apache.accumulo.core.client.sample.Sampler
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.Combiner
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.DebugIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.Filter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.FirstEntryInRowIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.LongCombiner
 
validateOptions(Map<String, String>) - Method in interface org.apache.accumulo.core.iterators.OptionDescriber
Check to see if an options map contains all options required by an iterator and that the option values are in the expected formats.
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.OrIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.SortedKeyIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.TypedValueCombiner
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.AgeOffFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.BigDecimalCombiner
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.CfCqSliceSeekingFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.ColumnAgeOffFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.LargeRowFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.RegExFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.RowEncodingIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.TimestampFilter
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.TransformingIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.VersioningIterator
 
validateOptions(Map<String, String>) - Method in class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
validateProperty(Properties, ClientProperty) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
 
validateRFileName(String) - Static method in class org.apache.accumulo.core.metadata.ValidationUtil
 
ValidationUtil - Class in org.apache.accumulo.core.metadata
Utility class for validation of tablet file paths.
ValidationUtil() - Constructor for class org.apache.accumulo.core.metadata.ValidationUtil
 
Validator<T> - Class in org.apache.accumulo.core.util
A class that validates arguments of a specified generic type.
Validator(Function<T, Optional<String>>) - Constructor for class org.apache.accumulo.core.util.Validator
Constructor to build a validator given the mapping function that validates.
Validators - Class in org.apache.accumulo.core.util
 
value - Variable in class org.apache.accumulo.core.data.Value
 
value - Variable in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
value - Variable in class org.apache.accumulo.core.iterators.user.IntersectingIterator
 
value - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
value - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
value - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
value - Variable in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
Value - Class in org.apache.accumulo.core.data
A byte sequence that is usable as a key or value.
Value() - Constructor for class org.apache.accumulo.core.data.Value
Creates a zero-size sequence.
Value(byte[]) - Constructor for class org.apache.accumulo.core.data.Value
Creates a Value using a byte array as the initial value.
Value(byte[], boolean) - Constructor for class org.apache.accumulo.core.data.Value
Creates a Value using a byte array as the initial value.
Value(byte[], int, int) - Constructor for class org.apache.accumulo.core.data.Value
Creates a Value based on a range in a byte array.
Value(CharSequence) - Constructor for class org.apache.accumulo.core.data.Value
Creates a value using the UTF-8 encoding of the CharSequence
Value(ByteBuffer) - Constructor for class org.apache.accumulo.core.data.Value
Creates a Value using the bytes in a buffer as the initial value.
Value(Value) - Constructor for class org.apache.accumulo.core.data.Value
Creates a new Value based on another.
Value(Text) - Constructor for class org.apache.accumulo.core.data.Value
Creates a Value using the bytes of the Text.
VALUE - org.apache.accumulo.core.dataImpl.thrift.TKeyValue._Fields
 
VALUE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
 
VALUE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
 
VALUE - org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
 
VALUE - org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
 
VALUE_REGEX - Static variable in class org.apache.accumulo.core.iterators.user.RegExFilter
 
Value.Comparator - Class in org.apache.accumulo.core.data
A Comparator optimized for Value.
ValueFormatException - Exception in org.apache.accumulo.core.iterators
Exception used for TypedValueCombiner and it's Encoders decode() function
ValueFormatException(Exception) - Constructor for exception org.apache.accumulo.core.iterators.ValueFormatException
 
ValueFormatException(String) - Constructor for exception org.apache.accumulo.core.iterators.ValueFormatException
 
ValueIterator(SortedKeyValueIterator<Key, Value>) - Constructor for class org.apache.accumulo.core.iterators.Combiner.ValueIterator
Constructs an iterator over Values whose Keys are versions of the current topKey of the source SortedKeyValueIterator.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.InitialTableState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ScanState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.ScanType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.admin.TimeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.ConditionalWriter.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.Durability
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.ScannerBase.ConsistencyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.client.security.SecurityErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.TabletType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ConfigurationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.CompactionSettings
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.TCompactionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.conf.ClientProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.conf.Property
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.conf.PropertyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.LoadPlan.RangeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.Mutation.SERIALIZED_FORMAT
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.data.PartialKey
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCMStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyValue._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.fate.Fate.TxInfo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeExistsPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeMissingPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock.BlockPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.file.FilePrefix
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.iterators.LongCombiner.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.iterators.user.SeekingFilter.AdvanceResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.iterators.user.SummingArrayCombiner.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator.Behavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.lock.ServiceLock.LockLossReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.lock.ServiceLockData.ThriftService
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.state.tables.TableState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.BulkImportState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.BulkImportStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.Compacting._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.DeadServer._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerGoalState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.RecoveryStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.TableInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.TabletLoadState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.metadata.schema.Ample.DataLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.metadata.schema.Ample.ReadConsistency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState.FinalState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.LocationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.metadata.TabletState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.ColumnVisibility.NodeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.SystemPermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.security.TablePermission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.singletons.SingletonManager.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.spi.cache.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.spi.compaction.CompactionKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.spi.crypto.CryptoEnvironment.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment.Scope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.spi.scan.ScanDispatch.CacheUsage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.spi.scan.ScanInfo.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.spi.scan.ScanServerAttempt.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tablet.thrift.TUnloadTabletGoal
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.DataFileInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TDurability
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.ScanState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.ScanType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Returns the enum constant of this type with the specified name.
values - Variable in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
values() - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionHost.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.ActiveCompaction.CompactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.InitialTableState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.ScanState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.ScanType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.admin.TimeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.ConditionalWriter.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.Durability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.ScannerBase.ConsistencyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.client.security.SecurityErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.accumulo.core.client.security.tokens.AuthenticationToken.Properties
 
values() - Static method in enum org.apache.accumulo.core.clientImpl.TabletType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ConfigurationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.SecurityErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TableOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TableOperationExceptionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TDiskUsage._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.CompactionSettings
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.TCompactionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompaction._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.TExternalCompactionList._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.conf.ClientProperty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.conf.Property
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.conf.PropertyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.LoadPlan.RangeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.Mutation.SERIALIZED_FORMAT
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.data.PartialKey
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.InitialScan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.IterInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.MultiScanResult._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.ScanResult._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCMResult._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCMStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TColumn._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TCondition._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConditionalSession._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKey._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyExtent._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TKeyValue._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TRange._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TRowRange._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaries._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummary._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.fate.Fate.TxInfo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.fate.ReadOnlyTStore.TStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeExistsPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.fate.zookeeper.ZooUtil.NodeMissingPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.file.blockfile.cache.lru.CachedBlock.BlockPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.file.FilePrefix
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.gc.thrift.GcCycleStats._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.gc.thrift.GCStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.iterators.IteratorUtil.IteratorScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.iterators.LongCombiner.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.iterators.user.SeekingFilter.AdvanceResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.iterators.user.SummingArrayCombiner.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator.Behavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.lock.ServiceLock.LockLossReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.lock.ServiceLockData.ThriftService
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.state.tables.TableState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.BulkImportState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.BulkImportStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.Compacting._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.DeadServer._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerGoalState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ManagerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.RecoveryStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.TableInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.TabletLoadState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.TabletSplit._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.manager.thrift.ThriftPropertyException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.metadata.schema.Ample.DataLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.metadata.schema.Ample.ReadConsistency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.metadata.schema.ExternalCompactionFinalState.FinalState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.ColumnType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.metadata.schema.TabletMetadata.LocationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.metadata.TabletState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.QualityOfProtection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.rpc.SaslConnectionParams.SaslMechanism
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.ColumnVisibility.NodeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.NamespacePermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.SystemPermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.security.TablePermission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TCredentials._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationToken._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.singletons.SingletonManager.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.spi.cache.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.spi.compaction.CompactionKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.spi.crypto.CryptoEnvironment.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.spi.fs.VolumeChooserEnvironment.Scope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.spi.scan.ScanDispatch.CacheUsage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.spi.scan.ScanInfo.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.spi.scan.ScanServerAttempt.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tablet.thrift.TUnloadTabletGoal
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.DataFileInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletingest.thrift.TDurability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.ActiveScan._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.ScanState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.ScanType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActionStats._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.InputFile._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.IteratorConfig._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TabletStats._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionStats._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TCompactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.accumulo.core.util.MapCounter
 
VALUES - org.apache.accumulo.core.dataImpl.thrift.TMutation._Fields
 
VAR_LEN_ENCODER - Static variable in class org.apache.accumulo.core.iterators.LongCombiner
 
VAR_LONG_ARRAY_ENCODER - Static variable in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner
 
VARLEN - org.apache.accumulo.core.iterators.LongCombiner.Type
indicates a variable-length encoding of a Long using LongCombiner.VarLenEncoder
VARLEN - org.apache.accumulo.core.iterators.user.SummingArrayCombiner.Type
indicates a variable-length encoding of a list of Longs using SummingArrayCombiner.VarLongArrayEncoder
VarLenEncoder() - Constructor for class org.apache.accumulo.core.iterators.LongCombiner.VarLenEncoder
 
VarLongArrayEncoder() - Constructor for class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.VarLongArrayEncoder
 
ve - Variable in class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
ve - Variable in class org.apache.accumulo.core.iteratorsImpl.system.VisibilityFilter
 
vectorSize - Variable in class org.apache.accumulo.core.bloomfilter.Filter
The vector size of this filter.
version - Variable in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
version - Variable in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
Version - Class in org.apache.accumulo.core.util
 
Version() - Constructor for class org.apache.accumulo.core.util.Version
 
Version(short, short) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Constructor.
Version(DataInput) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Construct the Version object by reading from the input stream.
VERSION - org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties._Fields
 
VERSION - org.apache.accumulo.core.manager.thrift.TabletServerStatus._Fields
 
VERSION - Static variable in class org.apache.accumulo.core.Constants
 
VERSION - Static variable in class org.apache.accumulo.core.FilteredConstants
 
VERSION - Static variable in class org.apache.accumulo.core.spi.crypto.AESCryptoService.AESCBCCryptoModule
 
VERSION - Static variable in class org.apache.accumulo.core.spi.crypto.NoCryptoService
 
VERSION_DIR - Static variable in class org.apache.accumulo.core.Constants
 
VERSION1 - org.apache.accumulo.core.data.Mutation.SERIALIZED_FORMAT
 
VERSION2 - org.apache.accumulo.core.data.Mutation.SERIALIZED_FORMAT
 
VersioningIterator - Class in org.apache.accumulo.core.iterators.user
 
VersioningIterator() - Constructor for class org.apache.accumulo.core.iterators.user.VersioningIterator
 
VIOLATED - org.apache.accumulo.core.client.ConditionalWriter.Status
mutation violated a constraint and was not written
VIOLATED - org.apache.accumulo.core.dataImpl.thrift.TCMStatus
 
VIOLATION_CODE - org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
 
VIOLATION_DESCRIPTION - org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary._Fields
 
VIOLATION_SUMMARIES - org.apache.accumulo.core.dataImpl.thrift.UpdateErrors._Fields
 
VIOLATION_SUMMARIES - org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException._Fields
 
violationCode - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
violationCode - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
violationDescription - Variable in class org.apache.accumulo.core.data.ConstraintViolationSummary
 
violationDescription - Variable in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
Violations - Class in org.apache.accumulo.core.constraints
A class for accumulating constraint violations across a number of mutations.
Violations() - Constructor for class org.apache.accumulo.core.constraints.Violations
Creates a new empty object.
violationSummaries - Variable in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
violationSummaries - Variable in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
visibility(byte[]) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnVisibilityStep
Set the column qualifier of the Key that this builder will build to the parameter.
visibility(byte[]) - Method in interface org.apache.accumulo.core.data.Mutation.VisibilityOptions
 
visibility(byte[], int, int) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnVisibilityStep
Set the column qualifier of the Key that this builder will build to the parameter.
visibility(CharSequence) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnVisibilityStep
Set the column qualifier of the Key that this builder will build to the parameter.
visibility(CharSequence) - Method in interface org.apache.accumulo.core.data.Mutation.VisibilityOptions
 
visibility(ByteBuffer) - Method in interface org.apache.accumulo.core.data.Mutation.VisibilityOptions
 
visibility(ColumnVisibility) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnVisibilityStep
Set the column qualifier of the Key that this builder will build to the parameter.
visibility(ColumnVisibility) - Method in interface org.apache.accumulo.core.data.Mutation.VisibilityOptions
 
visibility(Text) - Method in interface org.apache.accumulo.core.data.KeyBuilder.ColumnVisibilityStep
Set the column qualifier of the Key that this builder will build to the parameter.
visibility(Text) - Method in interface org.apache.accumulo.core.data.Mutation.VisibilityOptions
 
VisibilityConstraint - Class in org.apache.accumulo.core.data.constraints
A constraint that checks the visibility of columns against the actor's authorizations.
VisibilityConstraint() - Constructor for class org.apache.accumulo.core.data.constraints.VisibilityConstraint
 
VisibilityConverter() - Constructor for class org.apache.accumulo.core.cli.ClientOpts.VisibilityConverter
 
VisibilityEvaluator - Class in org.apache.accumulo.core.security
A class which evaluates visibility expressions against a set of authorizations.
VisibilityEvaluator(AuthorizationContainer) - Constructor for class org.apache.accumulo.core.security.VisibilityEvaluator
Creates a new evaluator for the authorizations found in the given container.
VisibilityEvaluator(Authorizations) - Constructor for class org.apache.accumulo.core.security.VisibilityEvaluator
Creates a new evaluator for the given collection of authorizations.
VisibilityFilter - Class in org.apache.accumulo.core.iterators.user
A SortedKeyValueIterator that filters based on ColumnVisibility.
VisibilityFilter - Class in org.apache.accumulo.core.iteratorsImpl.system
A SortedKeyValueIterator that filters based on ColumnVisibility and optimized for use with system iterators.
VisibilityFilter() - Constructor for class org.apache.accumulo.core.iterators.user.VisibilityFilter
 
VisibilityMetric - Class in org.apache.accumulo.core.file.rfile
Class that holds the components of a visibility metric.
VisibilityMetric(String, long, double, long, double) - Constructor for class org.apache.accumulo.core.file.rfile.VisibilityMetric
 
VisibilityParseException - Exception in org.apache.accumulo.core.security
An exception thrown when a visibility string cannot be parsed.
VisibilityParseException(String, byte[], int) - Constructor for exception org.apache.accumulo.core.security.VisibilityParseException
Creates a new exception.
VisibilitySummarizer - Class in org.apache.accumulo.core.client.summary.summarizers
Counts column visibility labels.
VisibilitySummarizer() - Constructor for class org.apache.accumulo.core.client.summary.summarizers.VisibilitySummarizer
 
VisMetricsGatherer - Class in org.apache.accumulo.core.file.rfile
This class provides visibility metrics per locality group.
VisMetricsGatherer() - Constructor for class org.apache.accumulo.core.file.rfile.VisMetricsGatherer
 
Volume - Interface in org.apache.accumulo.core.volume
Encapsulates a FileSystem and a base Path within that filesystem.
VolumeChooser - Interface in org.apache.accumulo.core.spi.fs
Helper used to select a volume from a set of Volume URIs.
VolumeChooserEnvironment - Interface in org.apache.accumulo.core.spi.fs
 
VolumeChooserEnvironment.Scope - Enum in org.apache.accumulo.core.spi.fs
A scope for the volume chooser environment; a TABLE scope should be accompanied by a tableId.
VolumeConfiguration - Class in org.apache.accumulo.core.volume
 
VolumeConfiguration() - Constructor for class org.apache.accumulo.core.volume.VolumeConfiguration
 
VolumeImpl - Class in org.apache.accumulo.core.volume
Basic Volume implementation that contains a FileSystem and a base path that should be used within that filesystem.
VolumeImpl(FileSystem, String) - Constructor for class org.apache.accumulo.core.volume.VolumeImpl
 
VolumeImpl(Path, Configuration) - Constructor for class org.apache.accumulo.core.volume.VolumeImpl
 
vProperties - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
vProperties - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
vProperties - Variable in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 

W

WAIT_FOR_WRITES - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args._Fields
 
WAIT_FOR_WRITES - org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args._Fields
 
WAIT_TIME_PROPERTY - Static variable in class org.apache.accumulo.core.spi.balancer.RegexGroupBalancer
 
waitForBalance() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForBalance
 
waitForBalance() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForBalance
 
waitForBalance() - Method in interface org.apache.accumulo.core.client.admin.InstanceOperations
Waits for the tablet balancer to run and return no migrations.
waitForBalance() - Method in class org.apache.accumulo.core.clientImpl.InstanceOperationsImpl
 
waitForBalance(TInfo) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
waitForBalance(TInfo) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
waitForBalance(TInfo, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
waitForBalance(TInfo, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
waitForBalance_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
waitForBalance_args(TInfo) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
waitForBalance_args(ManagerClientService.waitForBalance_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
Performs a deep copy on other.
waitForBalance_call(TInfo, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.waitForBalance_call
 
waitForBalance_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
waitForBalance_result(ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
waitForBalance_result(ManagerClientService.waitForBalance_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
Performs a deep copy on other.
waitForCompletion(long) - Method in class org.apache.accumulo.core.fate.Fate
 
waitForFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncProcessor.waitForFateOperation
 
waitForFateOperation() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.Processor.waitForFateOperation
 
waitForFateOperation(TInfo, TCredentials, long) - Method in class org.apache.accumulo.core.manager.thrift.FateService.Client
 
waitForFateOperation(TInfo, TCredentials, long) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.Iface
 
waitForFateOperation(TInfo, TCredentials, long, AsyncMethodCallback<String>) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient
 
waitForFateOperation(TInfo, TCredentials, long, AsyncMethodCallback<String>) - Method in interface org.apache.accumulo.core.manager.thrift.FateService.AsyncIface
 
waitForFateOperation_args() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
waitForFateOperation_args(TInfo, TCredentials, long) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
waitForFateOperation_args(FateService.waitForFateOperation_args) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
Performs a deep copy on other.
waitForFateOperation_call(TInfo, TCredentials, long, AsyncMethodCallback<String>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.waitForFateOperation_call
 
waitForFateOperation_result() - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
waitForFateOperation_result(String, ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
waitForFateOperation_result(FateService.waitForFateOperation_result) - Constructor for class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
Performs a deep copy on other.
waitForFlush() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncProcessor.waitForFlush
 
waitForFlush() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.Processor.waitForFlush
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.Client
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.Iface
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long, AsyncMethodCallback<Void>) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient
 
waitForFlush(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long, AsyncMethodCallback<Void>) - Method in interface org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncIface
 
waitForFlush_args() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
waitForFlush_args(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
waitForFlush_args(ManagerClientService.waitForFlush_args) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
Performs a deep copy on other.
waitForFlush_call(TInfo, TCredentials, String, ByteBuffer, ByteBuffer, long, long, AsyncMethodCallback<Void>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.waitForFlush_call
 
waitForFlush_result() - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
waitForFlush_result(ThriftSecurityException, ThriftTableOperationException, ThriftNotActiveServiceException) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
waitForFlush_result(ManagerClientService.waitForFlush_result) - Constructor for class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
Performs a deep copy on other.
waitForNextAttempt(Logger, String) - Method in class org.apache.accumulo.core.util.Retry
 
waitForStatusChange(long, EnumSet<ReadOnlyTStore.TStatus>) - Method in class org.apache.accumulo.core.fate.AgeOffStore
 
waitForStatusChange(long, EnumSet<ReadOnlyTStore.TStatus>) - Method in interface org.apache.accumulo.core.fate.ReadOnlyTStore
Wait for the status of a transaction to change
waitForStatusChange(long, EnumSet<ReadOnlyTStore.TStatus>) - Method in class org.apache.accumulo.core.fate.ZooStore
 
waitForWrites - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
waitForWrites - Variable in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
WAL - org.apache.accumulo.core.spi.crypto.CryptoEnvironment.Scope
 
WAL_DIR - Static variable in class org.apache.accumulo.core.Constants
 
WAL_NAME_PROP - Static variable in class org.apache.accumulo.core.spi.crypto.PerTableCryptoServiceFactory
 
walogs - Variable in class org.apache.accumulo.core.metadata.TabletLocationState
 
walRefsChanged(KeyExtent, Collection<String>) - Static method in class org.apache.accumulo.core.logging.TabletLogger
Called when the set of write ahead logs a tablet currently has unflushed data in changes.
wasCausedByHadoopShutdown(Exception) - Static method in class org.apache.accumulo.core.util.ShutdownUtil
 
wasLockAcquired() - Method in class org.apache.accumulo.core.lock.ServiceLock
indicates if the lock was acquired in the past....
watchCriticalFixedDelay(AccumuloConfiguration, long, Runnable) - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
 
watchCriticalScheduledTask(ScheduledFuture<?>) - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
 
watchNonCriticalScheduledTask(ScheduledFuture<?>) - Static method in class org.apache.accumulo.core.util.threads.ThreadPools
 
weight() - Method in class org.apache.accumulo.core.file.rfile.BlockIndex
 
weight() - Method in interface org.apache.accumulo.core.spi.cache.CacheEntry.Weighable
 
whoami() - Method in interface org.apache.accumulo.core.client.AccumuloClient
Get the current user for this AccumuloClient
whoami() - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
WholeColumnFamilyIterator - Class in org.apache.accumulo.core.iterators.user
The WholeColumnFamilyIterator is designed to provide row/cf-isolation so that queries see mutations as atomic.
WholeColumnFamilyIterator() - Constructor for class org.apache.accumulo.core.iterators.user.WholeColumnFamilyIterator
 
WholeRowIterator - Class in org.apache.accumulo.core.iterators.user
The WholeRowIterator is designed to provide row-isolation so that queries see mutations as atomic.
WholeRowIterator() - Constructor for class org.apache.accumulo.core.iterators.user.WholeRowIterator
 
willLimitShowLength() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
 
willPrintTimestamps() - Method in class org.apache.accumulo.core.util.format.FormatterConfig
 
willWrapIterator() - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
 
withAuthorizations(Authorizations) - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerOptions
The authorizations passed here will be used to filter Keys, from the Scanner, based on the content of the column visibility field.
withBounds(Range) - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerOptions
This option allows limiting the Scanner from reading data outside of a given range.
withCacheProvider(CacheProvider) - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
(Optional) Set the block cache pair to be used to optimize reads within the constructed reader.
withCompression(String) - Method in class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
withConfiguration(Collection<SummarizerConfiguration>) - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
Allows specifying a set of summaries, generated using the specified configs, to retrieve.
withConfiguration(SummarizerConfiguration...) - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
Allows specifying a set of summaries, generated using the specified configs, to retrieve.
withDataCache(long) - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerOptions
Enabling this option will cache RFiles data in memory.
withFileLenCache(Cache<String, Long>) - Method in class org.apache.accumulo.core.file.FileOperations.IndexReaderBuilder
 
withFileLenCache(Cache<String, Long>) - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
 
withFileSystem(FileSystem) - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerFSOptions
Optionally provide a FileSystem to open RFiles.
withFileSystem(FileSystem) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryFSOptions
Optionally provide a FileSystem to open RFiles.
withFileSystem(FileSystem) - Method in interface org.apache.accumulo.core.client.rfile.RFile.WriterFSOptions
Optionally provide a FileSystem to open a file to write a RFile.
withIndexCache(long) - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerOptions
Enabling this option will cache RFiles indexes in memory.
withMatchingConfiguration(String) - Method in interface org.apache.accumulo.core.client.admin.SummaryRetriever
Filters which summary data is retrieved.
withoutDefaultIterators() - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Currently the only default iterator is the VersioningIterator.
withoutSystemIterators() - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerOptions
By default the Scanner created will setup the default Accumulo system iterators.
withOverrides(Map<String, String>) - Method in interface org.apache.accumulo.core.conf.SiteConfiguration.OverridesOption
 
withRateLimiter(RateLimiter) - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
 
withRateLimiter(RateLimiter) - Method in class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
withSampler(SamplerConfiguration) - Method in interface org.apache.accumulo.core.client.rfile.RFile.WriterOptions
An option to store sample data in the generated RFile.
withSplits(SortedSet<Text>) - Method in class org.apache.accumulo.core.client.admin.NewTableConfiguration
Create a new table with pre-configured splits from the provided input collection.
withStartDisabled() - Method in class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
withSummarizers(SummarizerConfiguration...) - Method in interface org.apache.accumulo.core.client.rfile.RFile.WriterOptions
Enable generating summary data in the created RFile by running Summarizer's based on the specified configuration.
withTableConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations.IndexReaderBuilder
 
withTableConfiguration(AccumuloConfiguration) - Method in interface org.apache.accumulo.core.file.FileOperations.IndexReaderTableConfiguration
 
withTableConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations.ReaderBuilder
 
withTableConfiguration(AccumuloConfiguration) - Method in interface org.apache.accumulo.core.file.FileOperations.ReaderTableConfiguration
 
withTableConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations.ScanReaderBuilder
 
withTableConfiguration(AccumuloConfiguration) - Method in interface org.apache.accumulo.core.file.FileOperations.ScanReaderTableConfiguration
 
withTableConfiguration(AccumuloConfiguration) - Method in class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
withTableConfiguration(AccumuloConfiguration) - Method in interface org.apache.accumulo.core.file.FileOperations.WriterTableConfiguration
 
withTableProperties(Iterable<Map.Entry<String, String>>) - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerOptions
Construct the Scanner with iterators specified in a tables properties.
withTableProperties(Iterable<Map.Entry<String, String>>) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryOptions
Retrieve summaries with provided tables properties.
withTableProperties(Iterable<Map.Entry<String, String>>) - Method in interface org.apache.accumulo.core.client.rfile.RFile.WriterOptions
Create an RFile using the same configuration as an Accumulo table.
withTableProperties(Map<String, String>) - Method in interface org.apache.accumulo.core.client.rfile.RFile.ScannerOptions
 
withTableProperties(Map<String, String>) - Method in interface org.apache.accumulo.core.client.rfile.RFile.SummaryOptions
 
withTableProperties(Map<String, String>) - Method in interface org.apache.accumulo.core.client.rfile.RFile.WriterOptions
 
withUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in interface org.apache.accumulo.core.client.AccumuloClient.ClientFactory
Override default handling of uncaught exceptions in client threads
withUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
withVisibilityCacheSize(int) - Method in interface org.apache.accumulo.core.client.rfile.RFile.WriterOptions
 
wrap(Runnable) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
wrap(Callable<T>) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
wrap(TStore<T>, Function<Repo<T>, String>) - Static method in class org.apache.accumulo.core.logging.FateLogger
 
wrap(FileSKVWriter, AccumuloConfiguration, boolean) - Static method in class org.apache.accumulo.core.summary.SummaryWriter
 
wrap(SortedKeyValueIterator<Key, Value>, boolean, DeletingIterator.Behavior) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.DeletingIterator
 
wrap(SortedKeyValueIterator<Key, Value>, Set<Column>) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.ColumnQualifierFilter
 
wrap(SortedKeyValueIterator<Key, Value>, Authorizations, byte[]) - Static method in class org.apache.accumulo.core.iteratorsImpl.system.VisibilityFilter
 
wrapFileIterator(InterruptibleIterator) - Method in class org.apache.accumulo.core.metadata.schema.DataFileValue
Use per file information from the metadata table to wrap the raw iterator over a file with iterators that may take action based on data set in the metadata table.
wrapKey(Key, Key) - Static method in class org.apache.accumulo.core.spi.crypto.AESCryptoService
 
WrappingIterator - Class in org.apache.accumulo.core.iterators
A convenience class for implementing iterators that select, but do not modify, entries read from a source iterator.
WrappingIterator() - Constructor for class org.apache.accumulo.core.iterators.WrappingIterator
 
wrapService(T) - Static method in class org.apache.accumulo.core.trace.TraceUtil
 
write(byte[]) - Method in class org.apache.accumulo.core.crypto.streams.BlockedOutputStream
 
write(byte[]) - Method in class org.apache.accumulo.core.crypto.streams.RFileCipherOutputStream
 
write(byte[]) - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
write(byte[]) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.clientImpl.lexicoder.FixedByteArrayOutputStream
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.crypto.streams.BlockedOutputStream
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.crypto.streams.DiscardCloseOutputStream
It is very important to override this method!! The underlying method from FilterOutputStream calls write a single byte at a time and will kill performance.
write(byte[], int, int) - Method in class org.apache.accumulo.core.crypto.streams.NoFlushOutputStream
It is very important to override this method!! The underlying method from FilterOutputStream calls write a single byte at a time and will kill performance.
write(byte[], int, int) - Method in class org.apache.accumulo.core.crypto.streams.RFileCipherOutputStream
Override of CipherOutputStream's write to count the number of bytes that have been encrypted.
write(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.CompressionAlgorithm.FinishOnFlushCompressionStream
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionOutputStream
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.file.streams.RateLimitedOutputStream
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.rpc.FilterTransport
 
write(byte[], int, int) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
write(int) - Method in class org.apache.accumulo.core.clientImpl.lexicoder.FixedByteArrayOutputStream
 
write(int) - Method in class org.apache.accumulo.core.crypto.streams.BlockedOutputStream
 
write(int) - Method in class org.apache.accumulo.core.crypto.streams.RFileCipherOutputStream
Override of CipherOutputStream's write for a single byte to count it.
write(int) - Method in class org.apache.accumulo.core.file.rfile.bcfile.IdentityCodec.IdentityCompressionOutputStream
 
write(int) - Method in class org.apache.accumulo.core.file.streams.RateLimitedOutputStream
 
write(int) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
write(DataOutput) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
write(DataOutput) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
write(DataOutput) - Method in class org.apache.accumulo.core.bloomfilter.Filter
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.BatchWriterConfig
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.IteratorSetting
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.security.tokens.KerberosToken
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.security.tokens.NullToken
 
write(DataOutput) - Method in class org.apache.accumulo.core.client.security.tokens.PasswordToken
 
write(DataOutput) - Method in class org.apache.accumulo.core.clientImpl.AuthenticationTokenIdentifier
 
write(DataOutput) - Method in class org.apache.accumulo.core.clientImpl.DelegationTokenImpl
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Column
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Key
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Mutation
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Range
 
write(DataOutput) - Method in class org.apache.accumulo.core.data.Value
 
write(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.bcfile.Utils.Version
Write the object to a DataOutput.
write(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.MultiLevelIndex.IndexEntry
 
write(DataOutput) - Method in class org.apache.accumulo.core.file.rfile.RelativeKey
 
write(DataOutput) - Method in class org.apache.accumulo.core.sample.impl.SamplerConfigurationImpl
 
write(DataOutput, ByteBuffer) - Static method in class org.apache.accumulo.core.util.ByteBufferUtil
 
write(DataOutputStream, Long) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.FixedLongArrayEncoder
 
write(DataOutputStream, Long) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.VarLongArrayEncoder
 
write(DataOutputStream, V) - Method in class org.apache.accumulo.core.iterators.user.SummingArrayCombiner.DOSArrayEncoder
 
write(Iterator<ConditionalMutation>) - Method in interface org.apache.accumulo.core.client.ConditionalWriter
This method returns one result for each mutation passed to it.
write(ConditionalMutation) - Method in interface org.apache.accumulo.core.client.ConditionalWriter
This method has the same thread safety guarantees as ConditionalWriter.write(Iterator)
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.authenticateUser_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeAuthorizations_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.changeLocalUserPassword_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkClass_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkNamespaceClass_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.checkTableClass_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.createLocalUser_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.dropLocalUser_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getConfiguration_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getDiskUsage_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getInstanceId_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceConfiguration_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getNamespaceProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getRootTabletLocation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getSystemProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableConfiguration_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getTableProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getUserAuthorizations_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedNamespaceProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedSystemProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getVersionedTableProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.getZooKeepers_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantNamespacePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantSystemPermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.grantTablePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasNamespacePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasSystemPermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.hasTablePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.isActive_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.listLocalUsers_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.ping_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeNamespacePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeSystemPermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.revokeTablePermission_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.TDiskUsage
 
write(TProtocol) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftConcurrentModificationException
 
write(TProtocol) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftNotActiveServiceException
 
write(TProtocol) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftSecurityException
 
write(TProtocol) - Method in exception org.apache.accumulo.core.clientImpl.thrift.ThriftTableOperationException
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.fails_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.success_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.throwsError_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.TInfo
 
write(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.TVersionedProperties
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.cancel_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionCompleted_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.compactionFailed_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompactionJob_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getCompletedCompactions_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.getRunningCompactions_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.updateCompactionStatus_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.cancel_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getActiveCompactions_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompaction_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.getRunningCompactionId_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.TCompactionStatusUpdate
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompaction
 
write(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.TExternalCompactionList
 
write(TProtocol) - Method in exception org.apache.accumulo.core.compaction.thrift.UnknownCompactionIdException
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialMultiScan
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.InitialScan
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.IterInfo
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.MultiScanResult
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.ScanResult
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCMResult
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TColumn
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TCondition
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalMutation
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConditionalSession
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TConstraintViolationSummary
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKey
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyExtent
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TKeyValue
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TMutation
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRange
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TRowRange
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaries
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummarizerConfiguration
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummary
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.TSummaryRequest
 
write(TProtocol) - Method in class org.apache.accumulo.core.dataImpl.thrift.UpdateErrors
 
write(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GcCycleStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.getStatus_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCStatus
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.BulkImportStatus
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.Compacting
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.DeadServer
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.beginFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.cancelFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.executeFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.finishFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.waitForFateOperation_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getActiveTservers_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getDelegationToken_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.getManagerStats_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.initiateFlush_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyNamespaceProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifySystemProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.modifyTableProperties_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeNamespaceProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeSystemProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.removeTableProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportSplitExtent_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.reportTabletStatus_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setManagerGoalState_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setNamespaceProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setSystemProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.setTableProperty_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdown_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.shutdownTabletServer_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForBalance_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.waitForFlush_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerMonitorInfo
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.RecoveryStatus
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.TableInfo
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.TabletServerStatus
 
write(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.TabletSplit
 
write(TProtocol) - Method in exception org.apache.accumulo.core.manager.thrift.ThriftPropertyException
 
write(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationKey
 
write(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TAuthenticationTokenIdentifier
 
write(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TCredentials
 
write(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationToken
 
write(TProtocol) - Method in class org.apache.accumulo.core.securityImpl.thrift.TDelegationTokenConfig
 
write(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.chop_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.flushTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.loadTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.splitTablet_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.unloadTablet_args
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletingest.thrift.ConstraintViolationException
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.DataFileInfo
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.applyUpdates_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeConditionalUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.closeUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.conditionalUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.invalidateConditionalUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.loadFiles_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startConditionalUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.startUpdate_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.update_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.ActiveScan
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletscan.thrift.ScanServerBusyException
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeMultiScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.closeScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueMultiScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.continueScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.getActiveScans_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startMultiScan_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.startScan_result
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TooManyFilesException
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletscan.thrift.TSampleNotPresentException
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TSamplerConfiguration
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActionStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.ActiveCompaction
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.InputFile
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.IteratorConfig
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NoSuchScanIDException
 
write(TProtocol) - Method in exception org.apache.accumulo.core.tabletserver.thrift.NotServingTabletException
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compact_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFailed_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.compactionJobFinished_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.contiuneGetSummaries_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.fastHalt_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.flush_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveCompactions_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getActiveLogs_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getCompactionQueueInfo_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getHistoricalStats_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletServerStatus_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.getTabletStats_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.halt_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.removeLogs_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.reserveCompactionJob_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummaries_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesForPartition_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_args
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.startGetSummariesFromFiles_result
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionQueueSummary
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TCompactionStats
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TExternalCompactionJob
 
write(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TIteratorSetting
 
WRITE - org.apache.accumulo.core.security.NamespacePermission
 
WRITE - org.apache.accumulo.core.security.TablePermission
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.authenticate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.authenticateUser_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.changeAuthorizations_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.changeLocalUserPassword_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkClass_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkNamespaceClass_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.checkTableClass_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.createLocalUser_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.dropLocalUser_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getConfiguration_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getDiskUsage_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getInstanceId_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceConfiguration_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getNamespaceProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getRootTabletLocation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getSystemProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableConfiguration_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getTableProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getUserAuthorizations_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedNamespaceProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedSystemProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getVersionedTableProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.getZooKeepers_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantNamespacePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantSystemPermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.grantTablePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasNamespacePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasSystemPermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.hasTablePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.isActive_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.listLocalUsers_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.ping_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeNamespacePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeSystemPermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ClientService.AsyncClient.revokeTablePermission_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.fails_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.success_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.clientImpl.thrift.ThriftTest.AsyncClient.throwsError_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.cancel_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.compactionCompleted_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.compactionFailed_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompactionJob_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getCompletedCompactions_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.getRunningCompactions_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactionCoordinatorService.AsyncClient.updateCompactionStatus_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.cancel_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getActiveCompactions_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompaction_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.compaction.thrift.CompactorService.AsyncClient.getRunningCompactionId_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.gc.thrift.GCMonitorService.AsyncClient.getStatus_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.beginFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.cancelFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.executeFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.finishFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.FateService.AsyncClient.waitForFateOperation_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getActiveTservers_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getDelegationToken_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.getManagerStats_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.initiateFlush_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifyNamespaceProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifySystemProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.modifyTableProperties_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeNamespaceProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeSystemProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.removeTableProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.reportSplitExtent_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.reportTabletStatus_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setManagerGoalState_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setNamespaceProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setSystemProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.setTableProperty_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.shutdown_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.shutdownTabletServer_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.waitForBalance_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.manager.thrift.ManagerClientService.AsyncClient.waitForFlush_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.chop_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.flushTablet_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.loadTablet_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.splitTablet_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tablet.thrift.TabletManagementClientService.AsyncClient.unloadTablet_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.applyUpdates_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.closeConditionalUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.closeUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.conditionalUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.invalidateConditionalUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.loadFiles_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.startConditionalUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.startUpdate_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletingest.thrift.TabletIngestClientService.AsyncClient.update_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.closeMultiScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.closeScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.continueMultiScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.continueScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.getActiveScans_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.startMultiScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletscan.thrift.TabletScanClientService.AsyncClient.startScan_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.compact_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.compactionJobFailed_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.compactionJobFinished_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.contiuneGetSummaries_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.fastHalt_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.flush_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getActiveCompactions_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getActiveLogs_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getCompactionQueueInfo_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getHistoricalStats_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getTabletServerStatus_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.getTabletStats_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.halt_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.removeLogs_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.reserveCompactionJob_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummaries_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummariesForPartition_call
 
write_args(TProtocol) - Method in class org.apache.accumulo.core.tabletserver.thrift.TabletServerClientService.AsyncClient.startGetSummariesFromFiles_call
 
writeBoolean(boolean) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeByte(int) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeBytes(String) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeChar(int) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeChars(String) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeConfig(SummarizerConfiguration, DataOutputStream) - Method in class org.apache.accumulo.core.summary.SummaryWriter
 
writeDouble(double) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeFloat(float) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeInt(int) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeLoadMapping(SortedMap<KeyExtent, Bulk.Files>, String, BulkSerialize.Output) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkSerialize
Serialize bulk load mapping to "loadmap.json"
writeLock() - Method in class org.apache.accumulo.core.fate.zookeeper.DistributedReadWriteLock
 
writeLong(long) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeParams(byte[], DataOutputStream) - Static method in class org.apache.accumulo.core.crypto.CryptoUtils
Write the decryption parameters to the DataOutputStream
Writer - Class in org.apache.accumulo.core.clientImpl
 
Writer() - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
Creates a new writer.
Writer(int) - Constructor for class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
Creates a new writer.
Writer(ClientContext, TableId) - Constructor for class org.apache.accumulo.core.clientImpl.Writer
 
Writer(BCFile.Writer, int) - Constructor for class org.apache.accumulo.core.file.rfile.RFile.Writer
 
Writer(BCFile.Writer, int, int, SamplerConfigurationImpl, Sampler) - Constructor for class org.apache.accumulo.core.file.rfile.RFile.Writer
 
Writer(FSDataOutputStream, RateLimiter, String, Configuration, CryptoService) - Constructor for class org.apache.accumulo.core.file.rfile.bcfile.BCFile.Writer
Constructor
WriterBuilder() - Constructor for class org.apache.accumulo.core.file.FileOperations.WriterBuilder
 
writeRenameMap(Map<String, String>, String, BulkSerialize.Output) - Static method in class org.apache.accumulo.core.clientImpl.bulk.BulkSerialize
Writes rename file to JSON.
writeShort(int) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeString(DataOutput, String) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Write a String as a VInt n, followed by n Bytes as in Text format.
writeTo(DataOutput) - Method in class org.apache.accumulo.core.dataImpl.KeyExtent
Serialize this KeyExtent.
writeUTF(String) - Method in class org.apache.accumulo.core.sample.impl.DataoutputHasher
 
writeVInt(byte[], int, int) - Static method in class org.apache.accumulo.core.util.UnsynchronizedBuffer
Writes a variable int directly to a byte array.
writeVInt(int) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
Adds an integer value to this writer's buffer.
writeVInt(DataOutput, byte[], int) - Static method in class org.apache.accumulo.core.util.UnsynchronizedBuffer
Use the provided byte[] to buffer only the bytes used to write out the integer i to the DataOutput out.
writeVInt(DataOutput, int) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Encoding an integer into a variable-length encoding format.
writeVLong(byte[], int, long) - Static method in class org.apache.accumulo.core.util.UnsynchronizedBuffer
Writes a variable long directly to a byte array.
writeVLong(long) - Method in class org.apache.accumulo.core.util.UnsynchronizedBuffer.Writer
Adds a long value to this writer's buffer.
writeVLong(DataOutput, byte[], long) - Static method in class org.apache.accumulo.core.util.UnsynchronizedBuffer
Use the provided byte[] to buffer only the bytes used to write out the long i to the DataOutput out.
writeVLong(DataOutput, long) - Static method in class org.apache.accumulo.core.file.rfile.bcfile.Utils
Encoding a Long integer into a variable-length encoding format.

X

xor(Filter) - Method in class org.apache.accumulo.core.bloomfilter.BloomFilter
 
xor(Filter) - Method in class org.apache.accumulo.core.bloomfilter.DynamicBloomFilter
 
xor(Filter) - Method in class org.apache.accumulo.core.bloomfilter.Filter
Performs a logical XOR between this filter and a specified filter.

Y

yield(K) - Method in class org.apache.accumulo.core.iterators.YieldCallback
Called by the iterator when a next or seek call yields control.
YieldCallback<K> - Class in org.apache.accumulo.core.iterators
This callback handles the state of yielding within an iterator
YieldCallback() - Constructor for class org.apache.accumulo.core.iterators.YieldCallback
 
YieldingKeyValueIterator<K extends org.apache.hadoop.io.WritableComparable<?>,​V extends org.apache.hadoop.io.Writable> - Interface in org.apache.accumulo.core.iterators
An iterator that supports yielding on a next or seek call (only used by SortedKeyValueIterators)

Z

ZBULK_FAILED_COPYQ - Static variable in class org.apache.accumulo.core.Constants
 
ZCOMPACTORS - Static variable in class org.apache.accumulo.core.Constants
 
ZCONF_LEGACY - Static variable in class org.apache.accumulo.core.Constants
 
ZCONFIG - Static variable in class org.apache.accumulo.core.Constants
 
ZCOORDINATOR - Static variable in class org.apache.accumulo.core.Constants
 
ZCOORDINATOR_LOCK - Static variable in class org.apache.accumulo.core.Constants
 
ZcStat() - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooCache.ZcStat
 
ZDEAD - Static variable in class org.apache.accumulo.core.Constants
 
ZDEADTSERVERS - Static variable in class org.apache.accumulo.core.Constants
 
ZDELEGATION_TOKEN_KEYS - Static variable in class org.apache.accumulo.core.Constants
Base znode for storing secret keys that back delegation tokens
ZFATE - Static variable in class org.apache.accumulo.core.Constants
 
ZGC - Static variable in class org.apache.accumulo.core.Constants
 
ZGC_LOCK - Static variable in class org.apache.accumulo.core.Constants
 
ZHDFS_RESERVATIONS - Static variable in class org.apache.accumulo.core.Constants
 
ZINSTANCES - Static variable in class org.apache.accumulo.core.Constants
 
zkTimeout(int) - Method in interface org.apache.accumulo.core.client.AccumuloClient.ConnectionOptions
Build using Zookeeper timeout
zkTimeout(int) - Method in class org.apache.accumulo.core.clientImpl.ClientContext.ClientBuilderImpl
 
ZMANAGER_GOAL_STATE - Static variable in class org.apache.accumulo.core.Constants
 
ZMANAGER_LOCK - Static variable in class org.apache.accumulo.core.Constants
 
ZMANAGER_TICK - Static variable in class org.apache.accumulo.core.Constants
 
ZMANAGERS - Static variable in class org.apache.accumulo.core.Constants
 
ZMONITOR - Static variable in class org.apache.accumulo.core.Constants
 
ZMONITOR_HTTP_ADDR - Static variable in class org.apache.accumulo.core.Constants
 
ZMONITOR_LOCK - Static variable in class org.apache.accumulo.core.Constants
 
ZNAMESPACE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
ZNAMESPACES - Static variable in class org.apache.accumulo.core.Constants
 
ZNEXT_FILE - Static variable in class org.apache.accumulo.core.Constants
 
ZooCache - Class in org.apache.accumulo.core.fate.zookeeper
A cache for values stored in ZooKeeper.
ZooCache(ZooReader, Watcher) - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooCache
Creates a new cache.
ZooCache.ZcStat - Class in org.apache.accumulo.core.fate.zookeeper
 
zooCacheClearer(Object, ZooCache) - Static method in class org.apache.accumulo.core.util.cleaner.CleanerUtil
 
ZooCacheFactory - Class in org.apache.accumulo.core.fate.zookeeper
A factory for ZooCache instances.
ZooCacheFactory() - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooCacheFactory
 
zooKeeper - Variable in class org.apache.accumulo.core.lock.ServiceLock
 
ZookeeperLockChecker - Class in org.apache.accumulo.core.clientImpl
 
ZooReader - Class in org.apache.accumulo.core.fate.zookeeper
 
ZooReader(String, int) - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooReader
 
ZooReader.ZKFunction<R> - Interface in org.apache.accumulo.core.fate.zookeeper
 
ZooReader.ZKFunctionMutator<R> - Interface in org.apache.accumulo.core.fate.zookeeper
 
ZooReaderWriter - Class in org.apache.accumulo.core.fate.zookeeper
 
ZooReaderWriter(AccumuloConfiguration) - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooReaderWriter
 
ZooReaderWriter.Mutator - Interface in org.apache.accumulo.core.fate.zookeeper
 
ZooReservation - Class in org.apache.accumulo.core.fate.zookeeper
 
ZooReservation() - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooReservation
 
ZooSession - Class in org.apache.accumulo.core.fate.zookeeper
 
ZooSession() - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooSession
 
ZooSession.ZooSessionShutdownException - Exception in org.apache.accumulo.core.fate.zookeeper
 
ZooSessionShutdownException(String) - Constructor for exception org.apache.accumulo.core.fate.zookeeper.ZooSession.ZooSessionShutdownException
 
ZooStore<T> - Class in org.apache.accumulo.core.fate
 
ZooStore(String, ZooReaderWriter) - Constructor for class org.apache.accumulo.core.fate.ZooStore
 
ZooUtil - Class in org.apache.accumulo.core.fate.zookeeper
 
ZooUtil() - Constructor for class org.apache.accumulo.core.fate.zookeeper.ZooUtil
 
ZooUtil.LockID - Class in org.apache.accumulo.core.fate.zookeeper
 
ZooUtil.NodeExistsPolicy - Enum in org.apache.accumulo.core.fate.zookeeper
 
ZooUtil.NodeMissingPolicy - Enum in org.apache.accumulo.core.fate.zookeeper
 
ZPROBLEMS - Static variable in class org.apache.accumulo.core.Constants
 
ZRECOVERY - Static variable in class org.apache.accumulo.core.Constants
 
ZROOT - Static variable in class org.apache.accumulo.core.Constants
 
ZROOT_TABLET - Static variable in class org.apache.accumulo.core.metadata.RootTable
ZK path relative to the zookeeper node where the root tablet metadata is stored.
ZROOT_TABLET_GC_CANDIDATES - Static variable in class org.apache.accumulo.core.metadata.RootTable
ZK path relative to the zookeeper node where the root tablet gc candidates are stored.
ZSSERVERS - Static variable in class org.apache.accumulo.core.Constants
 
ZStandard - Class in org.apache.accumulo.core.spi.file.rfile.compression
 
ZStandard() - Constructor for class org.apache.accumulo.core.spi.file.rfile.compression.ZStandard
 
ZTABLE_COMPACT_CANCEL_ID - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_COMPACT_ID - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_DELETE_MARKER - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_FLUSH_ID - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_LOCKS - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_NAME - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_NAMESPACE - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLE_STATE - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLES - Static variable in class org.apache.accumulo.core.Constants
 
ZTABLES_INITIAL_ID - Static variable in class org.apache.accumulo.core.Constants
 
ZTRACERS - Static variable in class org.apache.accumulo.core.Constants
 
ZTSERVERS - Static variable in class org.apache.accumulo.core.Constants
 
ZUSERS - Static variable in class org.apache.accumulo.core.Constants
 

_

_getTableIdDetectNamespaceNotFound(String) - Method in class org.apache.accumulo.core.clientImpl.ClientContext
 
_getTableIdDetectNamespaceNotFound(String) - Method in class org.apache.accumulo.core.util.tables.TableZooHelper
Lookup table ID in ZK.
_locateTablet(ClientContext, Text, boolean, boolean, boolean, TabletLocatorImpl.LockCheckerSession) - Method in class org.apache.accumulo.core.clientImpl.TabletLocatorImpl
 
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